repo_name
stringclasses
8 values
repo_url
stringclasses
8 values
repo_description
stringclasses
6 values
repo_stars
int64
6
15.8k
repo_forks
int64
192
3.6k
repo_last_updated
stringclasses
8 values
repo_created_at
stringclasses
8 values
repo_size
int64
34
2.13k
repo_license
stringclasses
4 values
language
stringclasses
3 values
text
stringlengths
0
6.32M
avg_line_length
float64
0
28.5k
max_line_length
int64
0
945k
alphnanum_fraction
float64
0
0.91
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import os import logging from airflow import DAG from airflow.utils.dates import days_ago from airflow.operators.bash import BashOperator from airflow.operators.python import PythonOperator from google.cloud import storage from airflow.providers.google.cloud.operators.bigquery import BigQueryCreateExternalTableOperator import pyarrow.csv as pv import pyarrow.parquet as pq PROJECT_ID = os.environ.get("GCP_PROJECT_ID") BUCKET = os.environ.get("GCP_GCS_BUCKET") dataset_file = "yellow_tripdata_2021-01.csv" dataset_url = f"https://s3.amazonaws.com/nyc-tlc/trip+data/{dataset_file}" path_to_local_home = os.environ.get("AIRFLOW_HOME", "/opt/airflow/") parquet_file = dataset_file.replace('.csv', '.parquet') BIGQUERY_DATASET = os.environ.get("BIGQUERY_DATASET", 'trips_data_all') def format_to_parquet(src_file): if not src_file.endswith('.csv'): logging.error("Can only accept source files in CSV format, for the moment") return table = pv.read_csv(src_file) pq.write_table(table, src_file.replace('.csv', '.parquet')) # NOTE: takes 20 mins, at an upload speed of 800kbps. Faster if your internet has a better upload speed def upload_to_gcs(bucket, object_name, local_file): """ Ref: https://cloud.google.com/storage/docs/uploading-objects#storage-upload-object-python :param bucket: GCS bucket name :param object_name: target path & file-name :param local_file: source path & file-name :return: """ # WORKAROUND to prevent timeout for files > 6 MB on 800 kbps upload speed. # (Ref: https://github.com/googleapis/python-storage/issues/74) storage.blob._MAX_MULTIPART_SIZE = 5 * 1024 * 1024 # 5 MB storage.blob._DEFAULT_CHUNKSIZE = 5 * 1024 * 1024 # 5 MB # End of Workaround client = storage.Client() bucket = client.bucket(bucket) blob = bucket.blob(object_name) blob.upload_from_filename(local_file) default_args = { "owner": "airflow", "start_date": days_ago(1), "depends_on_past": False, "retries": 1, } # NOTE: DAG declaration - using a Context Manager (an implicit way) with DAG( dag_id="data_ingestion_gcs_dag", schedule_interval="@daily", default_args=default_args, catchup=False, max_active_runs=1, tags=['dtc-de'], ) as dag: download_dataset_task = BashOperator( task_id="download_dataset_task", bash_command=f"curl -sSL {dataset_url} > {path_to_local_home}/{dataset_file}" ) format_to_parquet_task = PythonOperator( task_id="format_to_parquet_task", python_callable=format_to_parquet, op_kwargs={ "src_file": f"{path_to_local_home}/{dataset_file}", }, ) # TODO: Homework - research and try XCOM to communicate output values between 2 tasks/operators local_to_gcs_task = PythonOperator( task_id="local_to_gcs_task", python_callable=upload_to_gcs, op_kwargs={ "bucket": BUCKET, "object_name": f"raw/{parquet_file}", "local_file": f"{path_to_local_home}/{parquet_file}", }, ) bigquery_external_table_task = BigQueryCreateExternalTableOperator( task_id="bigquery_external_table_task", table_resource={ "tableReference": { "projectId": PROJECT_ID, "datasetId": BIGQUERY_DATASET, "tableId": "external_table", }, "externalDataConfiguration": { "sourceFormat": "PARQUET", "sourceUris": [f"gs://{BUCKET}/raw/{parquet_file}"], }, }, ) download_dataset_task >> format_to_parquet_task >> local_to_gcs_task >> bigquery_external_table_task
32.423423
104
0.65031
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import os from datetime import datetime from airflow import DAG from airflow.operators.bash import BashOperator from airflow.operators.python import PythonOperator from ingest_script import ingest_callable AIRFLOW_HOME = os.environ.get("AIRFLOW_HOME", "/opt/airflow/") PG_HOST = os.getenv('PG_HOST') PG_USER = os.getenv('PG_USER') PG_PASSWORD = os.getenv('PG_PASSWORD') PG_PORT = os.getenv('PG_PORT') PG_DATABASE = os.getenv('PG_DATABASE') local_workflow = DAG( "LocalIngestionDag", schedule_interval="0 6 2 * *", start_date=datetime(2021, 1, 1) ) URL_PREFIX = 'https://s3.amazonaws.com/nyc-tlc/trip+data' URL_TEMPLATE = URL_PREFIX + '/yellow_tripdata_{{ execution_date.strftime(\'%Y-%m\') }}.csv' OUTPUT_FILE_TEMPLATE = AIRFLOW_HOME + '/output_{{ execution_date.strftime(\'%Y-%m\') }}.csv' TABLE_NAME_TEMPLATE = 'yellow_taxi_{{ execution_date.strftime(\'%Y_%m\') }}' with local_workflow: wget_task = BashOperator( task_id='wget', bash_command=f'curl -sSL {URL_TEMPLATE} > {OUTPUT_FILE_TEMPLATE}' ) ingest_task = PythonOperator( task_id="ingest", python_callable=ingest_callable, op_kwargs=dict( user=PG_USER, password=PG_PASSWORD, host=PG_HOST, port=PG_PORT, db=PG_DATABASE, table_name=TABLE_NAME_TEMPLATE, csv_file=OUTPUT_FILE_TEMPLATE ), ) wget_task >> ingest_task
25.327273
92
0.639945
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import os from time import time import pandas as pd from sqlalchemy import create_engine def ingest_callable(user, password, host, port, db, table_name, csv_file, execution_date): print(table_name, csv_file, execution_date) engine = create_engine(f'postgresql://{user}:{password}@{host}:{port}/{db}') engine.connect() print('connection established successfully, inserting data...') t_start = time() df_iter = pd.read_csv(csv_file, iterator=True, chunksize=100000) df = next(df_iter) df.tpep_pickup_datetime = pd.to_datetime(df.tpep_pickup_datetime) df.tpep_dropoff_datetime = pd.to_datetime(df.tpep_dropoff_datetime) df.head(n=0).to_sql(name=table_name, con=engine, if_exists='replace') df.to_sql(name=table_name, con=engine, if_exists='append') t_end = time() print('inserted the first chunk, took %.3f second' % (t_end - t_start)) while True: t_start = time() try: df = next(df_iter) except StopIteration: print("completed") break df.tpep_pickup_datetime = pd.to_datetime(df.tpep_pickup_datetime) df.tpep_dropoff_datetime = pd.to_datetime(df.tpep_dropoff_datetime) df.to_sql(name=table_name, con=engine, if_exists='append') t_end = time() print('inserted another chunk, took %.3f second' % (t_end - t_start))
27.306122
90
0.6443
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import os from datetime import datetime from airflow import DAG from airflow.utils.dates import days_ago from airflow.operators.bash import BashOperator from airflow.operators.python import PythonOperator from google.cloud import storage PROJECT_ID = os.environ.get("GCP_PROJECT_ID", "pivotal-surfer-336713") BUCKET = os.environ.get("GCP_GCS_BUCKET", "dtc_data_lake_pivotal-surfer-336713") dataset_file = "yellow_tripdata_2021-01.csv" dataset_url = f"https://s3.amazonaws.com/nyc-tlc/trip+data/{dataset_file}" path_to_local_home = os.environ.get("AIRFLOW_HOME", "/opt/airflow/") path_to_creds = f"{path_to_local_home}/google_credentials.json" default_args = { "owner": "airflow", "start_date": days_ago(1), "depends_on_past": False, "retries": 1, } # # Takes 15-20 mins to run. Good case for using Spark (distributed processing, in place of chunks) # def upload_to_gcs(bucket, object_name, local_file): # """ # Ref: https://cloud.google.com/storage/docs/uploading-objects#storage-upload-object-python # :param bucket: GCS bucket name # :param object_name: target path & file-name # :param local_file: source path & file-name # :return: # """ # # WORKAROUND to prevent timeout for files > 6 MB on 800 kbps upload link. # # (Ref: https://github.com/googleapis/python-storage/issues/74) # storage.blob._MAX_MULTIPART_SIZE = 5 * 1024 * 1024 # 5 MB # storage.blob._DEFAULT_CHUNKSIZE = 5 * 1024 * 1024 # 5 MB # # client = storage.Client() # bucket = client.bucket(bucket) # # blob = bucket.blob(object_name) # # blob.chunk_size = 5 * 1024 * 1024 # blob.upload_from_filename(local_file) with DAG( dag_id="data_ingestion_gcs_dag", schedule_interval="@daily", default_args=default_args, catchup=True, max_active_runs=1, ) as dag: # Takes ~2 mins, depending upon your internet's download speed download_dataset_task = BashOperator( task_id="download_dataset_task", bash_command=f"curl -sS {dataset_url} > {path_to_local_home}/{dataset_file}" # "&& unzip {zip_file} && rm {zip_file}" ) # # APPROACH 1: (takes 20 mins, at an upload speed of 800Kbps. Faster if your internet has a better upload speed) # upload_to_gcs_task = PythonOperator( # task_id="upload_to_gcs_task", # python_callable=upload_to_gcs, # op_kwargs={ # "bucket": BUCKET, # "object_name": f"raw/{dataset_file}", # "local_file": f"{path_to_local_home}/{dataset_file}", # # }, # ) # OR APPROACH 2: (takes 20 mins, at an upload speed of 800Kbps. Faster if your internet has a better upload speed) # Ref: https://cloud.google.com/blog/products/gcp/optimizing-your-cloud-storage-performance-google-cloud-performance-atlas upload_to_gcs_task = BashOperator( task_id="upload_to_gcs_task", bash_command=f"gcloud auth activate-service-account --key-file={path_to_creds} && \ gsutil -m cp {path_to_local_home}/{dataset_file} gs://{BUCKET}", ) download_dataset_task >> upload_to_gcs_task
36.421687
128
0.66087
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import os import logging from datetime import datetime from airflow import DAG from airflow.utils.dates import days_ago from airflow.operators.bash import BashOperator from airflow.operators.python import PythonOperator from google.cloud import storage import pyarrow.csv as pv import pyarrow.parquet as pq PROJECT_ID = os.environ.get("GCP_PROJECT_ID") BUCKET = os.environ.get("GCP_GCS_BUCKET") AIRFLOW_HOME = os.environ.get("AIRFLOW_HOME", "/opt/airflow/") def format_to_parquet(src_file, dest_file): if not src_file.endswith('.csv'): logging.error("Can only accept source files in CSV format, for the moment") return table = pv.read_csv(src_file) pq.write_table(table, dest_file) def upload_to_gcs(bucket, object_name, local_file): client = storage.Client() bucket = client.bucket(bucket) blob = bucket.blob(object_name) blob.upload_from_filename(local_file) default_args = { "owner": "airflow", #"start_date": days_ago(1), "depends_on_past": False, "retries": 1, } def donwload_parquetize_upload_dag( dag, url_template, local_csv_path_template, local_parquet_path_template, gcs_path_template ): with dag: download_dataset_task = BashOperator( task_id="download_dataset_task", bash_command=f"curl -sSLf {url_template} > {local_csv_path_template}" ) format_to_parquet_task = PythonOperator( task_id="format_to_parquet_task", python_callable=format_to_parquet, op_kwargs={ "src_file": local_csv_path_template, "dest_file": local_parquet_path_template }, ) local_to_gcs_task = PythonOperator( task_id="local_to_gcs_task", python_callable=upload_to_gcs, op_kwargs={ "bucket": BUCKET, "object_name": gcs_path_template, "local_file": local_parquet_path_template, }, ) rm_task = BashOperator( task_id="rm_task", bash_command=f"rm {local_csv_path_template} {local_parquet_path_template}" ) download_dataset_task >> format_to_parquet_task >> local_to_gcs_task >> rm_task URL_PREFIX = 'https://s3.amazonaws.com/nyc-tlc/trip+data' YELLOW_TAXI_URL_TEMPLATE = URL_PREFIX + '/yellow_tripdata_{{ execution_date.strftime(\'%Y-%m\') }}.csv' YELLOW_TAXI_CSV_FILE_TEMPLATE = AIRFLOW_HOME + '/yellow_tripdata_{{ execution_date.strftime(\'%Y-%m\') }}.csv' YELLOW_TAXI_PARQUET_FILE_TEMPLATE = AIRFLOW_HOME + '/yellow_tripdata_{{ execution_date.strftime(\'%Y-%m\') }}.parquet' YELLOW_TAXI_GCS_PATH_TEMPLATE = "raw/yellow_tripdata/{{ execution_date.strftime(\'%Y\') }}/yellow_tripdata_{{ execution_date.strftime(\'%Y-%m\') }}.parquet" yellow_taxi_data_dag = DAG( dag_id="yellow_taxi_data_v2", schedule_interval="0 6 2 * *", start_date=datetime(2019, 1, 1), default_args=default_args, catchup=True, max_active_runs=3, tags=['dtc-de'], ) donwload_parquetize_upload_dag( dag=yellow_taxi_data_dag, url_template=YELLOW_TAXI_URL_TEMPLATE, local_csv_path_template=YELLOW_TAXI_CSV_FILE_TEMPLATE, local_parquet_path_template=YELLOW_TAXI_PARQUET_FILE_TEMPLATE, gcs_path_template=YELLOW_TAXI_GCS_PATH_TEMPLATE ) # https://s3.amazonaws.com/nyc-tlc/trip+data/green_tripdata_2021-01.csv GREEN_TAXI_URL_TEMPLATE = URL_PREFIX + '/green_tripdata_{{ execution_date.strftime(\'%Y-%m\') }}.csv' GREEN_TAXI_CSV_FILE_TEMPLATE = AIRFLOW_HOME + '/green_tripdata_{{ execution_date.strftime(\'%Y-%m\') }}.csv' GREEN_TAXI_PARQUET_FILE_TEMPLATE = AIRFLOW_HOME + '/green_tripdata_{{ execution_date.strftime(\'%Y-%m\') }}.parquet' GREEN_TAXI_GCS_PATH_TEMPLATE = "raw/green_tripdata/{{ execution_date.strftime(\'%Y\') }}/green_tripdata_{{ execution_date.strftime(\'%Y-%m\') }}.parquet" green_taxi_data_dag = DAG( dag_id="green_taxi_data_v1", schedule_interval="0 7 2 * *", start_date=datetime(2019, 1, 1), default_args=default_args, catchup=True, max_active_runs=3, tags=['dtc-de'], ) donwload_parquetize_upload_dag( dag=green_taxi_data_dag, url_template=GREEN_TAXI_URL_TEMPLATE, local_csv_path_template=GREEN_TAXI_CSV_FILE_TEMPLATE, local_parquet_path_template=GREEN_TAXI_PARQUET_FILE_TEMPLATE, gcs_path_template=GREEN_TAXI_GCS_PATH_TEMPLATE ) # https://nyc-tlc.s3.amazonaws.com/trip+data/fhv_tripdata_2021-01.csv FHV_TAXI_URL_TEMPLATE = URL_PREFIX + '/fhv_tripdata_{{ execution_date.strftime(\'%Y-%m\') }}.csv' FHV_TAXI_CSV_FILE_TEMPLATE = AIRFLOW_HOME + '/fhv_tripdata_{{ execution_date.strftime(\'%Y-%m\') }}.csv' FHV_TAXI_PARQUET_FILE_TEMPLATE = AIRFLOW_HOME + '/fhv_tripdata_{{ execution_date.strftime(\'%Y-%m\') }}.parquet' FHV_TAXI_GCS_PATH_TEMPLATE = "raw/fhv_tripdata/{{ execution_date.strftime(\'%Y\') }}/fhv_tripdata_{{ execution_date.strftime(\'%Y-%m\') }}.parquet" fhv_taxi_data_dag = DAG( dag_id="hfv_taxi_data_v1", schedule_interval="0 8 2 * *", start_date=datetime(2019, 1, 1), end_date=datetime(2020, 1, 1), default_args=default_args, catchup=True, max_active_runs=3, tags=['dtc-de'], ) donwload_parquetize_upload_dag( dag=fhv_taxi_data_dag, url_template=FHV_TAXI_URL_TEMPLATE, local_csv_path_template=FHV_TAXI_CSV_FILE_TEMPLATE, local_parquet_path_template=FHV_TAXI_PARQUET_FILE_TEMPLATE, gcs_path_template=FHV_TAXI_GCS_PATH_TEMPLATE ) # https://s3.amazonaws.com/nyc-tlc/misc/taxi+_zone_lookup.csv ZONES_URL_TEMPLATE = 'https://s3.amazonaws.com/nyc-tlc/misc/taxi+_zone_lookup.csv' ZONES_CSV_FILE_TEMPLATE = AIRFLOW_HOME + '/taxi_zone_lookup.csv' ZONES_PARQUET_FILE_TEMPLATE = AIRFLOW_HOME + '/taxi_zone_lookup.parquet' ZONES_GCS_PATH_TEMPLATE = "raw/taxi_zone/taxi_zone_lookup.parquet" zones_data_dag = DAG( dag_id="zones_data_v1", schedule_interval="@once", start_date=days_ago(1), default_args=default_args, catchup=True, max_active_runs=3, tags=['dtc-de'], ) donwload_parquetize_upload_dag( dag=zones_data_dag, url_template=ZONES_URL_TEMPLATE, local_csv_path_template=ZONES_CSV_FILE_TEMPLATE, local_parquet_path_template=ZONES_PARQUET_FILE_TEMPLATE, gcs_path_template=ZONES_GCS_PATH_TEMPLATE )
32.393617
156
0.665127
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import os import logging from airflow import DAG from airflow.utils.dates import days_ago from airflow.providers.google.cloud.operators.bigquery import BigQueryCreateExternalTableOperator, BigQueryInsertJobOperator from airflow.providers.google.cloud.transfers.gcs_to_gcs import GCSToGCSOperator PROJECT_ID = os.environ.get("GCP_PROJECT_ID") BUCKET = os.environ.get("GCP_GCS_BUCKET") path_to_local_home = os.environ.get("AIRFLOW_HOME", "/opt/airflow/") BIGQUERY_DATASET = os.environ.get("BIGQUERY_DATASET", 'trips_data_all') DATASET = "tripdata" COLOUR_RANGE = {'yellow': 'tpep_pickup_datetime', 'green': 'lpep_pickup_datetime'} INPUT_PART = "raw" INPUT_FILETYPE = "parquet" default_args = { "owner": "airflow", "start_date": days_ago(1), "depends_on_past": False, "retries": 1, } # NOTE: DAG declaration - using a Context Manager (an implicit way) with DAG( dag_id="gcs_2_bq_dag", schedule_interval="@daily", default_args=default_args, catchup=False, max_active_runs=1, tags=['dtc-de'], ) as dag: for colour, ds_col in COLOUR_RANGE.items(): move_files_gcs_task = GCSToGCSOperator( task_id=f'move_{colour}_{DATASET}_files_task', source_bucket=BUCKET, source_object=f'{INPUT_PART}/{colour}_{DATASET}*.{INPUT_FILETYPE}', destination_bucket=BUCKET, destination_object=f'{colour}/{colour}_{DATASET}', move_object=True ) bigquery_external_table_task = BigQueryCreateExternalTableOperator( task_id=f"bq_{colour}_{DATASET}_external_table_task", table_resource={ "tableReference": { "projectId": PROJECT_ID, "datasetId": BIGQUERY_DATASET, "tableId": f"{colour}_{DATASET}_external_table", }, "externalDataConfiguration": { "autodetect": "True", "sourceFormat": f"{INPUT_FILETYPE.upper()}", "sourceUris": [f"gs://{BUCKET}/{colour}/*"], }, }, ) CREATE_BQ_TBL_QUERY = ( f"CREATE OR REPLACE TABLE {BIGQUERY_DATASET}.{colour}_{DATASET} \ PARTITION BY DATE({ds_col}) \ AS \ SELECT * FROM {BIGQUERY_DATASET}.{colour}_{DATASET}_external_table;" ) # Create a partitioned table from external table bq_create_partitioned_table_job = BigQueryInsertJobOperator( task_id=f"bq_create_{colour}_{DATASET}_partitioned_table_task", configuration={ "query": { "query": CREATE_BQ_TBL_QUERY, "useLegacySql": False, } } ) move_files_gcs_task >> bigquery_external_table_task >> bq_create_partitioned_table_job
33.890244
124
0.58951
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
from confluent_kafka import Producer import argparse import csv from typing import Dict from time import sleep from settings import CONFLUENT_CLOUD_CONFIG, \ GREEN_TAXI_TOPIC, FHV_TAXI_TOPIC, \ GREEN_TRIP_DATA_PATH, FHV_TRIP_DATA_PATH class RideCSVProducer: def __init__(self, probs: Dict, ride_type: str): self.producer = Producer(**probs) self.ride_type = ride_type def parse_row(self, row): if self.ride_type == 'green': record = f'{row[5]}, {row[6]}' # PULocationID, DOLocationID key = str(row[0]) # vendor_id elif self.ride_type == 'fhv': record = f'{row[3]}, {row[4]}' # PULocationID, DOLocationID, key = str(row[0]) # dispatching_base_num return key, record def read_records(self, resource_path: str): records, ride_keys = [], [] with open(resource_path, 'r') as f: reader = csv.reader(f) header = next(reader) # skip the header for row in reader: key, record = self.parse_row(row) ride_keys.append(key) records.append(record) return zip(ride_keys, records) def publish(self, records: [str, str], topic: str): for key_value in records: key, value = key_value try: self.producer.poll(0) self.producer.produce(topic=topic, key=key, value=value) print(f"Producing record for <key: {key}, value:{value}>") except KeyboardInterrupt: break except BufferError as bfer: self.producer.poll(0.1) except Exception as e: print(f"Exception while producing record - {value}: {e}") self.producer.flush() sleep(10) if __name__ == "__main__": parser = argparse.ArgumentParser(description='Kafka Consumer') parser.add_argument('--type', type=str, default='green') args = parser.parse_args() if args.type == 'green': kafka_topic = GREEN_TAXI_TOPIC data_path = GREEN_TRIP_DATA_PATH elif args.type == 'fhv': kafka_topic = FHV_TAXI_TOPIC data_path = FHV_TRIP_DATA_PATH producer = RideCSVProducer(ride_type=args.type, probs=CONFLUENT_CLOUD_CONFIG) ride_records = producer.read_records(resource_path=data_path) producer.publish(records=ride_records, topic=kafka_topic)
32.819444
81
0.587921
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import pyspark.sql.types as T INPUT_DATA_PATH = '../../resources/rides.csv' BOOTSTRAP_SERVERS = 'localhost:9092' TOPIC_WINDOWED_VENDOR_ID_COUNT = 'vendor_counts_windowed' PRODUCE_TOPIC_RIDES_CSV = CONSUME_TOPIC_RIDES_CSV = 'rides_csv' RIDE_SCHEMA = T.StructType( [T.StructField("vendor_id", T.IntegerType()), T.StructField('tpep_pickup_datetime', T.TimestampType()), T.StructField('tpep_dropoff_datetime', T.TimestampType()), T.StructField("passenger_count", T.IntegerType()), T.StructField("trip_distance", T.FloatType()), T.StructField("payment_type", T.IntegerType()), T.StructField("total_amount", T.FloatType()), ])
34
63
0.691265
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
from pyspark.sql import SparkSession import pyspark.sql.functions as F from settings import CONFLUENT_CLOUD_CONFIG, GREEN_TAXI_TOPIC, FHV_TAXI_TOPIC, RIDES_TOPIC, ALL_RIDE_SCHEMA def read_from_kafka(consume_topic: str): # Spark Streaming DataFrame, connect to Kafka topic served at host in bootrap.servers option df_stream = spark \ .readStream \ .format("kafka") \ .option("kafka.bootstrap.servers", CONFLUENT_CLOUD_CONFIG['bootstrap.servers']) \ .option("subscribe", consume_topic) \ .option("startingOffsets", "earliest") \ .option("checkpointLocation", "checkpoint") \ .option("kafka.security.protocol", "SASL_SSL") \ .option("kafka.sasl.mechanism", "PLAIN") \ .option("kafka.sasl.jaas.config", f"""org.apache.kafka.common.security.plain.PlainLoginModule required username="{CONFLUENT_CLOUD_CONFIG['sasl.username']}" password="{CONFLUENT_CLOUD_CONFIG['sasl.password']}";""") \ .option("failOnDataLoss", False) \ .load() return df_stream def parse_rides(df, schema): """ take a Spark Streaming df and parse value col based on <schema>, return streaming df cols in schema """ assert df.isStreaming is True, "DataFrame doesn't receive streaming data" df = df.selectExpr("CAST(key AS STRING)", "CAST(value AS STRING)") # split attributes to nested array in one Column col = F.split(df['value'], ', ') # expand col to multiple top-level columns for idx, field in enumerate(schema): df = df.withColumn(field.name, col.getItem(idx).cast(field.dataType)) df = df.na.drop() df.printSchema() return df.select([field.name for field in schema]) def sink_console(df, output_mode: str = 'complete', processing_time: str = '5 seconds'): query = df.writeStream \ .outputMode(output_mode) \ .trigger(processingTime=processing_time) \ .format("console") \ .option("truncate", False) \ .start() \ .awaitTermination() return query # pyspark.sql.streaming.StreamingQuery def sink_kafka(df, topic, output_mode: str = 'complete'): query = df.writeStream \ .format("kafka") \ .option("kafka.bootstrap.servers", "pkc-75m1o.europe-west3.gcp.confluent.cloud:9092") \ .outputMode(output_mode) \ .option("topic", topic) \ .option("checkpointLocation", "checkpoint") \ .option("kafka.security.protocol", "SASL_SSL") \ .option("kafka.sasl.mechanism", "PLAIN") \ .option("kafka.sasl.jaas.config", f"""org.apache.kafka.common.security.plain.PlainLoginModule required username="{CONFLUENT_CLOUD_CONFIG['sasl.username']}" password="{CONFLUENT_CLOUD_CONFIG['sasl.password']}";""") \ .option("failOnDataLoss", False) \ .start() return query def op_groupby(df, column_names): df_aggregation = df.groupBy(column_names).count() return df_aggregation if __name__ == "__main__": spark = SparkSession.builder.appName('streaming-homework').getOrCreate() spark.sparkContext.setLogLevel('WARN') # Step 1: Consume GREEN_TAXI_TOPIC and FHV_TAXI_TOPIC df_green_rides = read_from_kafka(consume_topic=GREEN_TAXI_TOPIC) df_fhv_rides = read_from_kafka(consume_topic=FHV_TAXI_TOPIC) # Step 2: Publish green and fhv rides to RIDES_TOPIC kafka_sink_green_query = sink_kafka(df=df_green_rides, topic=RIDES_TOPIC, output_mode='append') kafka_sink_fhv_query = sink_kafka(df=df_fhv_rides, topic=RIDES_TOPIC, output_mode='append') # Step 3: Read RIDES_TOPIC and parse it in ALL_RIDE_SCHEMA df_all_rides = read_from_kafka(consume_topic=RIDES_TOPIC) df_all_rides = parse_rides(df_all_rides, ALL_RIDE_SCHEMA) # Step 4: Apply Aggregation on the all_rides df_pu_location_count = op_groupby(df_all_rides, ['PULocationID']) df_pu_location_count = df_pu_location_count.sort(F.col('count').desc()) # Step 5: Sink Aggregation Streams to Console console_sink_pu_location = sink_console(df_pu_location_count, output_mode='complete')
39.87
197
0.666911
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
#!/usr/bin/env python # coding: utf-8 import os import argparse from time import time import pandas as pd from sqlalchemy import create_engine def main(params): user = params.user password = params.password host = params.host port = params.port db = params.db table_name = params.table_name url = params.url # the backup files are gzipped, and it's important to keep the correct extension # for pandas to be able to open the file if url.endswith('.csv.gz'): csv_name = 'output.csv.gz' else: csv_name = 'output.csv' os.system(f"wget {url} -O {csv_name}") engine = create_engine(f'postgresql://{user}:{password}@{host}:{port}/{db}') df_iter = pd.read_csv(csv_name, iterator=True, chunksize=100000) df = next(df_iter) df.tpep_pickup_datetime = pd.to_datetime(df.tpep_pickup_datetime) df.tpep_dropoff_datetime = pd.to_datetime(df.tpep_dropoff_datetime) df.head(n=0).to_sql(name=table_name, con=engine, if_exists='replace') df.to_sql(name=table_name, con=engine, if_exists='append') while True: try: t_start = time() df = next(df_iter) df.tpep_pickup_datetime = pd.to_datetime(df.tpep_pickup_datetime) df.tpep_dropoff_datetime = pd.to_datetime(df.tpep_dropoff_datetime) df.to_sql(name=table_name, con=engine, if_exists='append') t_end = time() print('inserted another chunk, took %.3f second' % (t_end - t_start)) except StopIteration: print("Finished ingesting data into the postgres database") break if __name__ == '__main__': parser = argparse.ArgumentParser(description='Ingest CSV data to Postgres') parser.add_argument('--user', required=True, help='user name for postgres') parser.add_argument('--password', required=True, help='password for postgres') parser.add_argument('--host', required=True, help='host for postgres') parser.add_argument('--port', required=True, help='port for postgres') parser.add_argument('--db', required=True, help='database name for postgres') parser.add_argument('--table_name', required=True, help='name of the table where we will write the results to') parser.add_argument('--url', required=True, help='url of the csv file') args = parser.parse_args() main(args)
29.417722
115
0.642798
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import sys import pandas as pd print(sys.argv) day = sys.argv[1] # some fancy stuff with pandas print(f'job finished successfully for day = {day}')
12.909091
51
0.723684
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import io import os import requests import pandas as pd from google.cloud import storage """ Pre-reqs: 1. `pip install pandas pyarrow google-cloud-storage` 2. Set GOOGLE_APPLICATION_CREDENTIALS to your project/service-account key 3. Set GCP_GCS_BUCKET as your bucket or change default value of BUCKET """ # services = ['fhv','green','yellow'] init_url = 'https://github.com/DataTalksClub/nyc-tlc-data/releases/download/' # switch out the bucketname BUCKET = os.environ.get("GCP_GCS_BUCKET", "dtc-data-lake-bucketname") def upload_to_gcs(bucket, object_name, local_file): """ Ref: https://cloud.google.com/storage/docs/uploading-objects#storage-upload-object-python """ # # WORKAROUND to prevent timeout for files > 6 MB on 800 kbps upload speed. # # (Ref: https://github.com/googleapis/python-storage/issues/74) # storage.blob._MAX_MULTIPART_SIZE = 5 * 1024 * 1024 # 5 MB # storage.blob._DEFAULT_CHUNKSIZE = 5 * 1024 * 1024 # 5 MB client = storage.Client() bucket = client.bucket(bucket) blob = bucket.blob(object_name) blob.upload_from_filename(local_file) def web_to_gcs(year, service): for i in range(12): # sets the month part of the file_name string month = '0'+str(i+1) month = month[-2:] # csv file_name file_name = f"{service}_tripdata_{year}-{month}.csv.gz" # download it using requests via a pandas df request_url = f"{init_url}{service}/{file_name}" r = requests.get(request_url) open(file_name, 'wb').write(r.content) print(f"Local: {file_name}") # read it back into a parquet file df = pd.read_csv(file_name, compression='gzip') file_name = file_name.replace('.csv.gz', '.parquet') df.to_parquet(file_name, engine='pyarrow') print(f"Parquet: {file_name}") # upload it to gcs upload_to_gcs(BUCKET, f"{service}/{file_name}", file_name) print(f"GCS: {service}/{file_name}") web_to_gcs('2019', 'green') web_to_gcs('2020', 'green') # web_to_gcs('2019', 'yellow') # web_to_gcs('2020', 'yellow')
30.671642
93
0.642621
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
#!/usr/bin/env python # coding: utf-8 import argparse import pyspark from pyspark.sql import SparkSession from pyspark.sql import functions as F parser = argparse.ArgumentParser() parser.add_argument('--input_green', required=True) parser.add_argument('--input_yellow', required=True) parser.add_argument('--output', required=True) args = parser.parse_args() input_green = args.input_green input_yellow = args.input_yellow output = args.output spark = SparkSession.builder \ .appName('test') \ .getOrCreate() df_green = spark.read.parquet(input_green) df_green = df_green \ .withColumnRenamed('lpep_pickup_datetime', 'pickup_datetime') \ .withColumnRenamed('lpep_dropoff_datetime', 'dropoff_datetime') df_yellow = spark.read.parquet(input_yellow) df_yellow = df_yellow \ .withColumnRenamed('tpep_pickup_datetime', 'pickup_datetime') \ .withColumnRenamed('tpep_dropoff_datetime', 'dropoff_datetime') common_colums = [ 'VendorID', 'pickup_datetime', 'dropoff_datetime', 'store_and_fwd_flag', 'RatecodeID', 'PULocationID', 'DOLocationID', 'passenger_count', 'trip_distance', 'fare_amount', 'extra', 'mta_tax', 'tip_amount', 'tolls_amount', 'improvement_surcharge', 'total_amount', 'payment_type', 'congestion_surcharge' ] df_green_sel = df_green \ .select(common_colums) \ .withColumn('service_type', F.lit('green')) df_yellow_sel = df_yellow \ .select(common_colums) \ .withColumn('service_type', F.lit('yellow')) df_trips_data = df_green_sel.unionAll(df_yellow_sel) df_trips_data.registerTempTable('trips_data') df_result = spark.sql(""" SELECT -- Reveneue grouping PULocationID AS revenue_zone, date_trunc('month', pickup_datetime) AS revenue_month, service_type, -- Revenue calculation SUM(fare_amount) AS revenue_monthly_fare, SUM(extra) AS revenue_monthly_extra, SUM(mta_tax) AS revenue_monthly_mta_tax, SUM(tip_amount) AS revenue_monthly_tip_amount, SUM(tolls_amount) AS revenue_monthly_tolls_amount, SUM(improvement_surcharge) AS revenue_monthly_improvement_surcharge, SUM(total_amount) AS revenue_monthly_total_amount, SUM(congestion_surcharge) AS revenue_monthly_congestion_surcharge, -- Additional calculations AVG(passenger_count) AS avg_montly_passenger_count, AVG(trip_distance) AS avg_montly_trip_distance FROM trips_data GROUP BY 1, 2, 3 """) df_result.coalesce(1) \ .write.parquet(output, mode='overwrite')
21.75
72
0.690224
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
#!/usr/bin/env python # coding: utf-8 import argparse import pyspark from pyspark.sql import SparkSession from pyspark.sql import functions as F parser = argparse.ArgumentParser() parser.add_argument('--input_green', required=True) parser.add_argument('--input_yellow', required=True) parser.add_argument('--output', required=True) args = parser.parse_args() input_green = args.input_green input_yellow = args.input_yellow output = args.output spark = SparkSession.builder \ .appName('test') \ .getOrCreate() spark.conf.set('temporaryGcsBucket', 'dataproc-temp-europe-west6-828225226997-fckhkym8') df_green = spark.read.parquet(input_green) df_green = df_green \ .withColumnRenamed('lpep_pickup_datetime', 'pickup_datetime') \ .withColumnRenamed('lpep_dropoff_datetime', 'dropoff_datetime') df_yellow = spark.read.parquet(input_yellow) df_yellow = df_yellow \ .withColumnRenamed('tpep_pickup_datetime', 'pickup_datetime') \ .withColumnRenamed('tpep_dropoff_datetime', 'dropoff_datetime') common_colums = [ 'VendorID', 'pickup_datetime', 'dropoff_datetime', 'store_and_fwd_flag', 'RatecodeID', 'PULocationID', 'DOLocationID', 'passenger_count', 'trip_distance', 'fare_amount', 'extra', 'mta_tax', 'tip_amount', 'tolls_amount', 'improvement_surcharge', 'total_amount', 'payment_type', 'congestion_surcharge' ] df_green_sel = df_green \ .select(common_colums) \ .withColumn('service_type', F.lit('green')) df_yellow_sel = df_yellow \ .select(common_colums) \ .withColumn('service_type', F.lit('yellow')) df_trips_data = df_green_sel.unionAll(df_yellow_sel) df_trips_data.registerTempTable('trips_data') df_result = spark.sql(""" SELECT -- Reveneue grouping PULocationID AS revenue_zone, date_trunc('month', pickup_datetime) AS revenue_month, service_type, -- Revenue calculation SUM(fare_amount) AS revenue_monthly_fare, SUM(extra) AS revenue_monthly_extra, SUM(mta_tax) AS revenue_monthly_mta_tax, SUM(tip_amount) AS revenue_monthly_tip_amount, SUM(tolls_amount) AS revenue_monthly_tolls_amount, SUM(improvement_surcharge) AS revenue_monthly_improvement_surcharge, SUM(total_amount) AS revenue_monthly_total_amount, SUM(congestion_surcharge) AS revenue_monthly_congestion_surcharge, -- Additional calculations AVG(passenger_count) AS avg_montly_passenger_count, AVG(trip_distance) AS avg_montly_trip_distance FROM trips_data GROUP BY 1, 2, 3 """) df_result.write.format('bigquery') \ .option('table', output) \ .save()
22.069565
88
0.690422
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import argparse from typing import Dict, List from kafka import KafkaConsumer from settings import BOOTSTRAP_SERVERS, CONSUME_TOPIC_RIDES_CSV class RideCSVConsumer: def __init__(self, props: Dict): self.consumer = KafkaConsumer(**props) def consume_from_kafka(self, topics: List[str]): self.consumer.subscribe(topics=topics) print('Consuming from Kafka started') print('Available topics to consume: ', self.consumer.subscription()) while True: try: # SIGINT can't be handled when polling, limit timeout to 1 second. msg = self.consumer.poll(1.0) if msg is None or msg == {}: continue for msg_key, msg_values in msg.items(): for msg_val in msg_values: print(f'Key:{msg_val.key}-type({type(msg_val.key)}), ' f'Value:{msg_val.value}-type({type(msg_val.value)})') except KeyboardInterrupt: break self.consumer.close() if __name__ == '__main__': parser = argparse.ArgumentParser(description='Kafka Consumer') parser.add_argument('--topic', type=str, default=CONSUME_TOPIC_RIDES_CSV) args = parser.parse_args() topic = args.topic config = { 'bootstrap_servers': [BOOTSTRAP_SERVERS], 'auto_offset_reset': 'earliest', 'enable_auto_commit': True, 'key_deserializer': lambda key: int(key.decode('utf-8')), 'value_deserializer': lambda value: value.decode('utf-8'), 'group_id': 'consumer.group.id.csv-example.1', } csv_consumer = RideCSVConsumer(props=config) csv_consumer.consume_from_kafka(topics=[topic])
35.25
83
0.59632
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import csv from time import sleep from typing import Dict from kafka import KafkaProducer from settings import BOOTSTRAP_SERVERS, INPUT_DATA_PATH, PRODUCE_TOPIC_RIDES_CSV def delivery_report(err, msg): if err is not None: print("Delivery failed for record {}: {}".format(msg.key(), err)) return print('Record {} successfully produced to {} [{}] at offset {}'.format( msg.key(), msg.topic(), msg.partition(), msg.offset())) class RideCSVProducer: def __init__(self, props: Dict): self.producer = KafkaProducer(**props) # self.producer = Producer(producer_props) @staticmethod def read_records(resource_path: str): records, ride_keys = [], [] i = 0 with open(resource_path, 'r') as f: reader = csv.reader(f) header = next(reader) # skip the header for row in reader: # vendor_id, passenger_count, trip_distance, payment_type, total_amount records.append(f'{row[0]}, {row[1]}, {row[2]}, {row[3]}, {row[4]}, {row[9]}, {row[16]}') ride_keys.append(str(row[0])) i += 1 if i == 5: break return zip(ride_keys, records) def publish(self, topic: str, records: [str, str]): for key_value in records: key, value = key_value try: self.producer.send(topic=topic, key=key, value=value) print(f"Producing record for <key: {key}, value:{value}>") except KeyboardInterrupt: break except Exception as e: print(f"Exception while producing record - {value}: {e}") self.producer.flush() sleep(1) if __name__ == "__main__": config = { 'bootstrap_servers': [BOOTSTRAP_SERVERS], 'key_serializer': lambda x: x.encode('utf-8'), 'value_serializer': lambda x: x.encode('utf-8') } producer = RideCSVProducer(props=config) ride_records = producer.read_records(resource_path=INPUT_DATA_PATH) print(ride_records) producer.publish(topic=PRODUCE_TOPIC_RIDES_CSV, records=ride_records)
33.571429
104
0.574644
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
from typing import List, Dict class RideRecord: def __init__(self, arr: List[str]): self.vendor_id = int(arr[0]) self.passenger_count = int(arr[1]) self.trip_distance = float(arr[2]) self.payment_type = int(arr[3]) self.total_amount = float(arr[4]) @classmethod def from_dict(cls, d: Dict): return cls(arr=[ d['vendor_id'], d['passenger_count'], d['trip_distance'], d['payment_type'], d['total_amount'] ] ) def __repr__(self): return f'{self.__class__.__name__}: {self.__dict__}' def dict_to_ride_record(obj, ctx): if obj is None: return None return RideRecord.from_dict(obj) def ride_record_to_dict(ride_record: RideRecord, ctx): return ride_record.__dict__
21.648649
60
0.540024
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
from typing import Dict class RideRecordKey: def __init__(self, vendor_id): self.vendor_id = vendor_id @classmethod def from_dict(cls, d: Dict): return cls(vendor_id=d['vendor_id']) def __repr__(self): return f'{self.__class__.__name__}: {self.__dict__}' def dict_to_ride_record_key(obj, ctx): if obj is None: return None return RideRecordKey.from_dict(obj) def ride_record_key_to_dict(ride_record_key: RideRecordKey, ctx): return ride_record_key.__dict__
20.04
65
0.619048
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
from typing import List, Dict from decimal import Decimal from datetime import datetime class Ride: def __init__(self, arr: List[str]): self.vendor_id = arr[0] self.tpep_pickup_datetime = datetime.strptime(arr[1], "%Y-%m-%d %H:%M:%S"), self.tpep_dropoff_datetime = datetime.strptime(arr[2], "%Y-%m-%d %H:%M:%S"), self.passenger_count = int(arr[3]) self.trip_distance = Decimal(arr[4]) self.rate_code_id = int(arr[5]) self.store_and_fwd_flag = arr[6] self.pu_location_id = int(arr[7]) self.do_location_id = int(arr[8]) self.payment_type = arr[9] self.fare_amount = Decimal(arr[10]) self.extra = Decimal(arr[11]) self.mta_tax = Decimal(arr[12]) self.tip_amount = Decimal(arr[13]) self.tolls_amount = Decimal(arr[14]) self.improvement_surcharge = Decimal(arr[15]) self.total_amount = Decimal(arr[16]) self.congestion_surcharge = Decimal(arr[17]) @classmethod def from_dict(cls, d: Dict): return cls(arr=[ d['vendor_id'], d['tpep_pickup_datetime'][0], d['tpep_dropoff_datetime'][0], d['passenger_count'], d['trip_distance'], d['rate_code_id'], d['store_and_fwd_flag'], d['pu_location_id'], d['do_location_id'], d['payment_type'], d['fare_amount'], d['extra'], d['mta_tax'], d['tip_amount'], d['tolls_amount'], d['improvement_surcharge'], d['total_amount'], d['congestion_surcharge'], ] ) def __repr__(self): return f'{self.__class__.__name__}: {self.__dict__}'
32.396226
84
0.520068
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import faust from taxi_rides import TaxiRide from faust import current_event app = faust.App('datatalksclub.stream.v3', broker='kafka://localhost:9092', consumer_auto_offset_reset="earliest") topic = app.topic('datatalkclub.yellow_taxi_ride.json', value_type=TaxiRide) high_amount_rides = app.topic('datatalks.yellow_taxi_rides.high_amount') low_amount_rides = app.topic('datatalks.yellow_taxi_rides.low_amount') @app.agent(topic) async def process(stream): async for event in stream: if event.total_amount >= 40.0: await current_event().forward(high_amount_rides) else: await current_event().forward(low_amount_rides) if __name__ == '__main__': app.main()
31.318182
114
0.701408
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import csv from json import dumps from kafka import KafkaProducer from time import sleep producer = KafkaProducer(bootstrap_servers=['localhost:9092'], key_serializer=lambda x: dumps(x).encode('utf-8'), value_serializer=lambda x: dumps(x).encode('utf-8')) file = open('../../resources/rides.csv') csvreader = csv.reader(file) header = next(csvreader) for row in csvreader: key = {"vendorId": int(row[0])} value = {"vendorId": int(row[0]), "passenger_count": int(row[3]), "trip_distance": float(row[4]), "payment_type": int(row[9]), "total_amount": float(row[16])} producer.send('datatalkclub.yellow_taxi_ride.json', value=value, key=key) print("producing") sleep(1)
36
162
0.648173
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import faust from taxi_rides import TaxiRide app = faust.App('datatalksclub.stream.v2', broker='kafka://localhost:9092') topic = app.topic('datatalkclub.yellow_taxi_ride.json', value_type=TaxiRide) @app.agent(topic) async def start_reading(records): async for record in records: print(record) if __name__ == '__main__': app.main()
19.823529
76
0.694051
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import faust from taxi_rides import TaxiRide app = faust.App('datatalksclub.stream.v2', broker='kafka://localhost:9092') topic = app.topic('datatalkclub.yellow_taxi_ride.json', value_type=TaxiRide) vendor_rides = app.Table('vendor_rides', default=int) @app.agent(topic) async def process(stream): async for event in stream.group_by(TaxiRide.vendorId): vendor_rides[event.vendorId] += 1 if __name__ == '__main__': app.main()
23.833333
76
0.704036
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
import faust class TaxiRide(faust.Record, validation=True): vendorId: str passenger_count: int trip_distance: float payment_type: int total_amount: float
16.7
46
0.704545
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
from datetime import timedelta import faust from taxi_rides import TaxiRide app = faust.App('datatalksclub.stream.v2', broker='kafka://localhost:9092') topic = app.topic('datatalkclub.yellow_taxi_ride.json', value_type=TaxiRide) vendor_rides = app.Table('vendor_rides_windowed', default=int).tumbling( timedelta(minutes=1), expires=timedelta(hours=1), ) @app.agent(topic) async def process(stream): async for event in stream.group_by(TaxiRide.vendorId): vendor_rides[event.vendorId] += 1 if __name__ == '__main__': app.main()
23.26087
76
0.710952
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Python
from pyspark.sql import SparkSession import pyspark.sql.functions as F from settings import RIDE_SCHEMA, CONSUME_TOPIC_RIDES_CSV, TOPIC_WINDOWED_VENDOR_ID_COUNT def read_from_kafka(consume_topic: str): # Spark Streaming DataFrame, connect to Kafka topic served at host in bootrap.servers option df_stream = spark \ .readStream \ .format("kafka") \ .option("kafka.bootstrap.servers", "localhost:9092,broker:29092") \ .option("subscribe", consume_topic) \ .option("startingOffsets", "earliest") \ .option("checkpointLocation", "checkpoint") \ .load() return df_stream def parse_ride_from_kafka_message(df, schema): """ take a Spark Streaming df and parse value col based on <schema>, return streaming df cols in schema """ assert df.isStreaming is True, "DataFrame doesn't receive streaming data" df = df.selectExpr("CAST(key AS STRING)", "CAST(value AS STRING)") # split attributes to nested array in one Column col = F.split(df['value'], ', ') # expand col to multiple top-level columns for idx, field in enumerate(schema): df = df.withColumn(field.name, col.getItem(idx).cast(field.dataType)) return df.select([field.name for field in schema]) def sink_console(df, output_mode: str = 'complete', processing_time: str = '5 seconds'): write_query = df.writeStream \ .outputMode(output_mode) \ .trigger(processingTime=processing_time) \ .format("console") \ .option("truncate", False) \ .start() return write_query # pyspark.sql.streaming.StreamingQuery def sink_memory(df, query_name, query_template): query_df = df \ .writeStream \ .queryName(query_name) \ .format("memory") \ .start() query_str = query_template.format(table_name=query_name) query_results = spark.sql(query_str) return query_results, query_df def sink_kafka(df, topic): write_query = df.writeStream \ .format("kafka") \ .option("kafka.bootstrap.servers", "localhost:9092,broker:29092") \ .outputMode('complete') \ .option("topic", topic) \ .option("checkpointLocation", "checkpoint") \ .start() return write_query def prepare_df_to_kafka_sink(df, value_columns, key_column=None): columns = df.columns df = df.withColumn("value", F.concat_ws(', ', *value_columns)) if key_column: df = df.withColumnRenamed(key_column, "key") df = df.withColumn("key", df.key.cast('string')) return df.select(['key', 'value']) def op_groupby(df, column_names): df_aggregation = df.groupBy(column_names).count() return df_aggregation def op_windowed_groupby(df, window_duration, slide_duration): df_windowed_aggregation = df.groupBy( F.window(timeColumn=df.tpep_pickup_datetime, windowDuration=window_duration, slideDuration=slide_duration), df.vendor_id ).count() return df_windowed_aggregation if __name__ == "__main__": spark = SparkSession.builder.appName('streaming-examples').getOrCreate() spark.sparkContext.setLogLevel('WARN') # read_streaming data df_consume_stream = read_from_kafka(consume_topic=CONSUME_TOPIC_RIDES_CSV) print(df_consume_stream.printSchema()) # parse streaming data df_rides = parse_ride_from_kafka_message(df_consume_stream, RIDE_SCHEMA) print(df_rides.printSchema()) sink_console(df_rides, output_mode='append') df_trip_count_by_vendor_id = op_groupby(df_rides, ['vendor_id']) df_trip_count_by_pickup_date_vendor_id = op_windowed_groupby(df_rides, window_duration="10 minutes", slide_duration='5 minutes') # write the output out to the console for debugging / testing sink_console(df_trip_count_by_vendor_id) # write the output to the kafka topic df_trip_count_messages = prepare_df_to_kafka_sink(df=df_trip_count_by_pickup_date_vendor_id, value_columns=['count'], key_column='vendor_id') kafka_sink_query = sink_kafka(df=df_trip_count_messages, topic=TOPIC_WINDOWED_VENDOR_ID_COUNT) spark.streams.awaitAnyTermination()
35.586207
115
0.65449
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
/** * Autogenerated by Avro * * DO NOT EDIT DIRECTLY */ package schemaregistry; import org.apache.avro.generic.GenericArray; import org.apache.avro.specific.SpecificData; import org.apache.avro.util.Utf8; import org.apache.avro.message.BinaryMessageEncoder; import org.apache.avro.message.BinaryMessageDecoder; import org.apache.avro.message.SchemaStore; @org.apache.avro.specific.AvroGenerated public class RideRecord extends org.apache.avro.specific.SpecificRecordBase implements org.apache.avro.specific.SpecificRecord { private static final long serialVersionUID = 6805437803204402942L; public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"RideRecord\",\"namespace\":\"schemaregistry\",\"fields\":[{\"name\":\"vendor_id\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"}},{\"name\":\"passenger_count\",\"type\":\"int\"},{\"name\":\"trip_distance\",\"type\":\"double\"}]}"); public static org.apache.avro.Schema getClassSchema() { return SCHEMA$; } private static final SpecificData MODEL$ = new SpecificData(); private static final BinaryMessageEncoder<RideRecord> ENCODER = new BinaryMessageEncoder<>(MODEL$, SCHEMA$); private static final BinaryMessageDecoder<RideRecord> DECODER = new BinaryMessageDecoder<>(MODEL$, SCHEMA$); /** * Return the BinaryMessageEncoder instance used by this class. * @return the message encoder used by this class */ public static BinaryMessageEncoder<RideRecord> getEncoder() { return ENCODER; } /** * Return the BinaryMessageDecoder instance used by this class. * @return the message decoder used by this class */ public static BinaryMessageDecoder<RideRecord> getDecoder() { return DECODER; } /** * Create a new BinaryMessageDecoder instance for this class that uses the specified {@link SchemaStore}. * @param resolver a {@link SchemaStore} used to find schemas by fingerprint * @return a BinaryMessageDecoder instance for this class backed by the given SchemaStore */ public static BinaryMessageDecoder<RideRecord> createDecoder(SchemaStore resolver) { return new BinaryMessageDecoder<>(MODEL$, SCHEMA$, resolver); } /** * Serializes this RideRecord to a ByteBuffer. * @return a buffer holding the serialized data for this instance * @throws java.io.IOException if this instance could not be serialized */ public java.nio.ByteBuffer toByteBuffer() throws java.io.IOException { return ENCODER.encode(this); } /** * Deserializes a RideRecord from a ByteBuffer. * @param b a byte buffer holding serialized data for an instance of this class * @return a RideRecord instance decoded from the given buffer * @throws java.io.IOException if the given bytes could not be deserialized into an instance of this class */ public static RideRecord fromByteBuffer( java.nio.ByteBuffer b) throws java.io.IOException { return DECODER.decode(b); } private java.lang.String vendor_id; private int passenger_count; private double trip_distance; /** * Default constructor. Note that this does not initialize fields * to their default values from the schema. If that is desired then * one should use <code>newBuilder()</code>. */ public RideRecord() {} /** * All-args constructor. * @param vendor_id The new value for vendor_id * @param passenger_count The new value for passenger_count * @param trip_distance The new value for trip_distance */ public RideRecord(java.lang.String vendor_id, java.lang.Integer passenger_count, java.lang.Double trip_distance) { this.vendor_id = vendor_id; this.passenger_count = passenger_count; this.trip_distance = trip_distance; } @Override public org.apache.avro.specific.SpecificData getSpecificData() { return MODEL$; } @Override public org.apache.avro.Schema getSchema() { return SCHEMA$; } // Used by DatumWriter. Applications should not call. @Override public java.lang.Object get(int field$) { switch (field$) { case 0: return vendor_id; case 1: return passenger_count; case 2: return trip_distance; default: throw new IndexOutOfBoundsException("Invalid index: " + field$); } } // Used by DatumReader. Applications should not call. @Override @SuppressWarnings(value="unchecked") public void put(int field$, java.lang.Object value$) { switch (field$) { case 0: vendor_id = value$ != null ? value$.toString() : null; break; case 1: passenger_count = (java.lang.Integer)value$; break; case 2: trip_distance = (java.lang.Double)value$; break; default: throw new IndexOutOfBoundsException("Invalid index: " + field$); } } /** * Gets the value of the 'vendor_id' field. * @return The value of the 'vendor_id' field. */ public java.lang.String getVendorId() { return vendor_id; } /** * Sets the value of the 'vendor_id' field. * @param value the value to set. */ public void setVendorId(java.lang.String value) { this.vendor_id = value; } /** * Gets the value of the 'passenger_count' field. * @return The value of the 'passenger_count' field. */ public int getPassengerCount() { return passenger_count; } /** * Sets the value of the 'passenger_count' field. * @param value the value to set. */ public void setPassengerCount(int value) { this.passenger_count = value; } /** * Gets the value of the 'trip_distance' field. * @return The value of the 'trip_distance' field. */ public double getTripDistance() { return trip_distance; } /** * Sets the value of the 'trip_distance' field. * @param value the value to set. */ public void setTripDistance(double value) { this.trip_distance = value; } /** * Creates a new RideRecord RecordBuilder. * @return A new RideRecord RecordBuilder */ public static schemaregistry.RideRecord.Builder newBuilder() { return new schemaregistry.RideRecord.Builder(); } /** * Creates a new RideRecord RecordBuilder by copying an existing Builder. * @param other The existing builder to copy. * @return A new RideRecord RecordBuilder */ public static schemaregistry.RideRecord.Builder newBuilder(schemaregistry.RideRecord.Builder other) { if (other == null) { return new schemaregistry.RideRecord.Builder(); } else { return new schemaregistry.RideRecord.Builder(other); } } /** * Creates a new RideRecord RecordBuilder by copying an existing RideRecord instance. * @param other The existing instance to copy. * @return A new RideRecord RecordBuilder */ public static schemaregistry.RideRecord.Builder newBuilder(schemaregistry.RideRecord other) { if (other == null) { return new schemaregistry.RideRecord.Builder(); } else { return new schemaregistry.RideRecord.Builder(other); } } /** * RecordBuilder for RideRecord instances. */ @org.apache.avro.specific.AvroGenerated public static class Builder extends org.apache.avro.specific.SpecificRecordBuilderBase<RideRecord> implements org.apache.avro.data.RecordBuilder<RideRecord> { private java.lang.String vendor_id; private int passenger_count; private double trip_distance; /** Creates a new Builder */ private Builder() { super(SCHEMA$, MODEL$); } /** * Creates a Builder by copying an existing Builder. * @param other The existing Builder to copy. */ private Builder(schemaregistry.RideRecord.Builder other) { super(other); if (isValidValue(fields()[0], other.vendor_id)) { this.vendor_id = data().deepCopy(fields()[0].schema(), other.vendor_id); fieldSetFlags()[0] = other.fieldSetFlags()[0]; } if (isValidValue(fields()[1], other.passenger_count)) { this.passenger_count = data().deepCopy(fields()[1].schema(), other.passenger_count); fieldSetFlags()[1] = other.fieldSetFlags()[1]; } if (isValidValue(fields()[2], other.trip_distance)) { this.trip_distance = data().deepCopy(fields()[2].schema(), other.trip_distance); fieldSetFlags()[2] = other.fieldSetFlags()[2]; } } /** * Creates a Builder by copying an existing RideRecord instance * @param other The existing instance to copy. */ private Builder(schemaregistry.RideRecord other) { super(SCHEMA$, MODEL$); if (isValidValue(fields()[0], other.vendor_id)) { this.vendor_id = data().deepCopy(fields()[0].schema(), other.vendor_id); fieldSetFlags()[0] = true; } if (isValidValue(fields()[1], other.passenger_count)) { this.passenger_count = data().deepCopy(fields()[1].schema(), other.passenger_count); fieldSetFlags()[1] = true; } if (isValidValue(fields()[2], other.trip_distance)) { this.trip_distance = data().deepCopy(fields()[2].schema(), other.trip_distance); fieldSetFlags()[2] = true; } } /** * Gets the value of the 'vendor_id' field. * @return The value. */ public java.lang.String getVendorId() { return vendor_id; } /** * Sets the value of the 'vendor_id' field. * @param value The value of 'vendor_id'. * @return This builder. */ public schemaregistry.RideRecord.Builder setVendorId(java.lang.String value) { validate(fields()[0], value); this.vendor_id = value; fieldSetFlags()[0] = true; return this; } /** * Checks whether the 'vendor_id' field has been set. * @return True if the 'vendor_id' field has been set, false otherwise. */ public boolean hasVendorId() { return fieldSetFlags()[0]; } /** * Clears the value of the 'vendor_id' field. * @return This builder. */ public schemaregistry.RideRecord.Builder clearVendorId() { vendor_id = null; fieldSetFlags()[0] = false; return this; } /** * Gets the value of the 'passenger_count' field. * @return The value. */ public int getPassengerCount() { return passenger_count; } /** * Sets the value of the 'passenger_count' field. * @param value The value of 'passenger_count'. * @return This builder. */ public schemaregistry.RideRecord.Builder setPassengerCount(int value) { validate(fields()[1], value); this.passenger_count = value; fieldSetFlags()[1] = true; return this; } /** * Checks whether the 'passenger_count' field has been set. * @return True if the 'passenger_count' field has been set, false otherwise. */ public boolean hasPassengerCount() { return fieldSetFlags()[1]; } /** * Clears the value of the 'passenger_count' field. * @return This builder. */ public schemaregistry.RideRecord.Builder clearPassengerCount() { fieldSetFlags()[1] = false; return this; } /** * Gets the value of the 'trip_distance' field. * @return The value. */ public double getTripDistance() { return trip_distance; } /** * Sets the value of the 'trip_distance' field. * @param value The value of 'trip_distance'. * @return This builder. */ public schemaregistry.RideRecord.Builder setTripDistance(double value) { validate(fields()[2], value); this.trip_distance = value; fieldSetFlags()[2] = true; return this; } /** * Checks whether the 'trip_distance' field has been set. * @return True if the 'trip_distance' field has been set, false otherwise. */ public boolean hasTripDistance() { return fieldSetFlags()[2]; } /** * Clears the value of the 'trip_distance' field. * @return This builder. */ public schemaregistry.RideRecord.Builder clearTripDistance() { fieldSetFlags()[2] = false; return this; } @Override @SuppressWarnings("unchecked") public RideRecord build() { try { RideRecord record = new RideRecord(); record.vendor_id = fieldSetFlags()[0] ? this.vendor_id : (java.lang.String) defaultValue(fields()[0]); record.passenger_count = fieldSetFlags()[1] ? this.passenger_count : (java.lang.Integer) defaultValue(fields()[1]); record.trip_distance = fieldSetFlags()[2] ? this.trip_distance : (java.lang.Double) defaultValue(fields()[2]); return record; } catch (org.apache.avro.AvroMissingFieldException e) { throw e; } catch (java.lang.Exception e) { throw new org.apache.avro.AvroRuntimeException(e); } } } @SuppressWarnings("unchecked") private static final org.apache.avro.io.DatumWriter<RideRecord> WRITER$ = (org.apache.avro.io.DatumWriter<RideRecord>)MODEL$.createDatumWriter(SCHEMA$); @Override public void writeExternal(java.io.ObjectOutput out) throws java.io.IOException { WRITER$.write(this, SpecificData.getEncoder(out)); } @SuppressWarnings("unchecked") private static final org.apache.avro.io.DatumReader<RideRecord> READER$ = (org.apache.avro.io.DatumReader<RideRecord>)MODEL$.createDatumReader(SCHEMA$); @Override public void readExternal(java.io.ObjectInput in) throws java.io.IOException { READER$.read(this, SpecificData.getDecoder(in)); } @Override protected boolean hasCustomCoders() { return true; } @Override public void customEncode(org.apache.avro.io.Encoder out) throws java.io.IOException { out.writeString(this.vendor_id); out.writeInt(this.passenger_count); out.writeDouble(this.trip_distance); } @Override public void customDecode(org.apache.avro.io.ResolvingDecoder in) throws java.io.IOException { org.apache.avro.Schema.Field[] fieldOrder = in.readFieldOrderIfDiff(); if (fieldOrder == null) { this.vendor_id = in.readString(); this.passenger_count = in.readInt(); this.trip_distance = in.readDouble(); } else { for (int i = 0; i < 3; i++) { switch (fieldOrder[i].pos()) { case 0: this.vendor_id = in.readString(); break; case 1: this.passenger_count = in.readInt(); break; case 2: this.trip_distance = in.readDouble(); break; default: throw new java.io.IOException("Corrupt ResolvingDecoder."); } } } } }
29.533473
377
0.659381
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
/** * Autogenerated by Avro * * DO NOT EDIT DIRECTLY */ package schemaregistry; import org.apache.avro.generic.GenericArray; import org.apache.avro.specific.SpecificData; import org.apache.avro.util.Utf8; import org.apache.avro.message.BinaryMessageEncoder; import org.apache.avro.message.BinaryMessageDecoder; import org.apache.avro.message.SchemaStore; @org.apache.avro.specific.AvroGenerated public class RideRecordCompatible extends org.apache.avro.specific.SpecificRecordBase implements org.apache.avro.specific.SpecificRecord { private static final long serialVersionUID = 7163300507090021229L; public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"RideRecordCompatible\",\"namespace\":\"schemaregistry\",\"fields\":[{\"name\":\"vendorId\",\"type\":{\"type\":\"string\",\"avro.java.string\":\"String\"}},{\"name\":\"passenger_count\",\"type\":\"int\"},{\"name\":\"trip_distance\",\"type\":\"double\"},{\"name\":\"pu_location_id\",\"type\":[\"null\",\"long\"],\"default\":null}]}"); public static org.apache.avro.Schema getClassSchema() { return SCHEMA$; } private static final SpecificData MODEL$ = new SpecificData(); private static final BinaryMessageEncoder<RideRecordCompatible> ENCODER = new BinaryMessageEncoder<>(MODEL$, SCHEMA$); private static final BinaryMessageDecoder<RideRecordCompatible> DECODER = new BinaryMessageDecoder<>(MODEL$, SCHEMA$); /** * Return the BinaryMessageEncoder instance used by this class. * @return the message encoder used by this class */ public static BinaryMessageEncoder<RideRecordCompatible> getEncoder() { return ENCODER; } /** * Return the BinaryMessageDecoder instance used by this class. * @return the message decoder used by this class */ public static BinaryMessageDecoder<RideRecordCompatible> getDecoder() { return DECODER; } /** * Create a new BinaryMessageDecoder instance for this class that uses the specified {@link SchemaStore}. * @param resolver a {@link SchemaStore} used to find schemas by fingerprint * @return a BinaryMessageDecoder instance for this class backed by the given SchemaStore */ public static BinaryMessageDecoder<RideRecordCompatible> createDecoder(SchemaStore resolver) { return new BinaryMessageDecoder<>(MODEL$, SCHEMA$, resolver); } /** * Serializes this RideRecordCompatible to a ByteBuffer. * @return a buffer holding the serialized data for this instance * @throws java.io.IOException if this instance could not be serialized */ public java.nio.ByteBuffer toByteBuffer() throws java.io.IOException { return ENCODER.encode(this); } /** * Deserializes a RideRecordCompatible from a ByteBuffer. * @param b a byte buffer holding serialized data for an instance of this class * @return a RideRecordCompatible instance decoded from the given buffer * @throws java.io.IOException if the given bytes could not be deserialized into an instance of this class */ public static RideRecordCompatible fromByteBuffer( java.nio.ByteBuffer b) throws java.io.IOException { return DECODER.decode(b); } private java.lang.String vendorId; private int passenger_count; private double trip_distance; private java.lang.Long pu_location_id; /** * Default constructor. Note that this does not initialize fields * to their default values from the schema. If that is desired then * one should use <code>newBuilder()</code>. */ public RideRecordCompatible() {} /** * All-args constructor. * @param vendorId The new value for vendorId * @param passenger_count The new value for passenger_count * @param trip_distance The new value for trip_distance * @param pu_location_id The new value for pu_location_id */ public RideRecordCompatible(java.lang.String vendorId, java.lang.Integer passenger_count, java.lang.Double trip_distance, java.lang.Long pu_location_id) { this.vendorId = vendorId; this.passenger_count = passenger_count; this.trip_distance = trip_distance; this.pu_location_id = pu_location_id; } @Override public org.apache.avro.specific.SpecificData getSpecificData() { return MODEL$; } @Override public org.apache.avro.Schema getSchema() { return SCHEMA$; } // Used by DatumWriter. Applications should not call. @Override public java.lang.Object get(int field$) { switch (field$) { case 0: return vendorId; case 1: return passenger_count; case 2: return trip_distance; case 3: return pu_location_id; default: throw new IndexOutOfBoundsException("Invalid index: " + field$); } } // Used by DatumReader. Applications should not call. @Override @SuppressWarnings(value="unchecked") public void put(int field$, java.lang.Object value$) { switch (field$) { case 0: vendorId = value$ != null ? value$.toString() : null; break; case 1: passenger_count = (java.lang.Integer)value$; break; case 2: trip_distance = (java.lang.Double)value$; break; case 3: pu_location_id = (java.lang.Long)value$; break; default: throw new IndexOutOfBoundsException("Invalid index: " + field$); } } /** * Gets the value of the 'vendorId' field. * @return The value of the 'vendorId' field. */ public java.lang.String getVendorId() { return vendorId; } /** * Sets the value of the 'vendorId' field. * @param value the value to set. */ public void setVendorId(java.lang.String value) { this.vendorId = value; } /** * Gets the value of the 'passenger_count' field. * @return The value of the 'passenger_count' field. */ public int getPassengerCount() { return passenger_count; } /** * Sets the value of the 'passenger_count' field. * @param value the value to set. */ public void setPassengerCount(int value) { this.passenger_count = value; } /** * Gets the value of the 'trip_distance' field. * @return The value of the 'trip_distance' field. */ public double getTripDistance() { return trip_distance; } /** * Sets the value of the 'trip_distance' field. * @param value the value to set. */ public void setTripDistance(double value) { this.trip_distance = value; } /** * Gets the value of the 'pu_location_id' field. * @return The value of the 'pu_location_id' field. */ public java.lang.Long getPuLocationId() { return pu_location_id; } /** * Sets the value of the 'pu_location_id' field. * @param value the value to set. */ public void setPuLocationId(java.lang.Long value) { this.pu_location_id = value; } /** * Creates a new RideRecordCompatible RecordBuilder. * @return A new RideRecordCompatible RecordBuilder */ public static schemaregistry.RideRecordCompatible.Builder newBuilder() { return new schemaregistry.RideRecordCompatible.Builder(); } /** * Creates a new RideRecordCompatible RecordBuilder by copying an existing Builder. * @param other The existing builder to copy. * @return A new RideRecordCompatible RecordBuilder */ public static schemaregistry.RideRecordCompatible.Builder newBuilder(schemaregistry.RideRecordCompatible.Builder other) { if (other == null) { return new schemaregistry.RideRecordCompatible.Builder(); } else { return new schemaregistry.RideRecordCompatible.Builder(other); } } /** * Creates a new RideRecordCompatible RecordBuilder by copying an existing RideRecordCompatible instance. * @param other The existing instance to copy. * @return A new RideRecordCompatible RecordBuilder */ public static schemaregistry.RideRecordCompatible.Builder newBuilder(schemaregistry.RideRecordCompatible other) { if (other == null) { return new schemaregistry.RideRecordCompatible.Builder(); } else { return new schemaregistry.RideRecordCompatible.Builder(other); } } /** * RecordBuilder for RideRecordCompatible instances. */ @org.apache.avro.specific.AvroGenerated public static class Builder extends org.apache.avro.specific.SpecificRecordBuilderBase<RideRecordCompatible> implements org.apache.avro.data.RecordBuilder<RideRecordCompatible> { private java.lang.String vendorId; private int passenger_count; private double trip_distance; private java.lang.Long pu_location_id; /** Creates a new Builder */ private Builder() { super(SCHEMA$, MODEL$); } /** * Creates a Builder by copying an existing Builder. * @param other The existing Builder to copy. */ private Builder(schemaregistry.RideRecordCompatible.Builder other) { super(other); if (isValidValue(fields()[0], other.vendorId)) { this.vendorId = data().deepCopy(fields()[0].schema(), other.vendorId); fieldSetFlags()[0] = other.fieldSetFlags()[0]; } if (isValidValue(fields()[1], other.passenger_count)) { this.passenger_count = data().deepCopy(fields()[1].schema(), other.passenger_count); fieldSetFlags()[1] = other.fieldSetFlags()[1]; } if (isValidValue(fields()[2], other.trip_distance)) { this.trip_distance = data().deepCopy(fields()[2].schema(), other.trip_distance); fieldSetFlags()[2] = other.fieldSetFlags()[2]; } if (isValidValue(fields()[3], other.pu_location_id)) { this.pu_location_id = data().deepCopy(fields()[3].schema(), other.pu_location_id); fieldSetFlags()[3] = other.fieldSetFlags()[3]; } } /** * Creates a Builder by copying an existing RideRecordCompatible instance * @param other The existing instance to copy. */ private Builder(schemaregistry.RideRecordCompatible other) { super(SCHEMA$, MODEL$); if (isValidValue(fields()[0], other.vendorId)) { this.vendorId = data().deepCopy(fields()[0].schema(), other.vendorId); fieldSetFlags()[0] = true; } if (isValidValue(fields()[1], other.passenger_count)) { this.passenger_count = data().deepCopy(fields()[1].schema(), other.passenger_count); fieldSetFlags()[1] = true; } if (isValidValue(fields()[2], other.trip_distance)) { this.trip_distance = data().deepCopy(fields()[2].schema(), other.trip_distance); fieldSetFlags()[2] = true; } if (isValidValue(fields()[3], other.pu_location_id)) { this.pu_location_id = data().deepCopy(fields()[3].schema(), other.pu_location_id); fieldSetFlags()[3] = true; } } /** * Gets the value of the 'vendorId' field. * @return The value. */ public java.lang.String getVendorId() { return vendorId; } /** * Sets the value of the 'vendorId' field. * @param value The value of 'vendorId'. * @return This builder. */ public schemaregistry.RideRecordCompatible.Builder setVendorId(java.lang.String value) { validate(fields()[0], value); this.vendorId = value; fieldSetFlags()[0] = true; return this; } /** * Checks whether the 'vendorId' field has been set. * @return True if the 'vendorId' field has been set, false otherwise. */ public boolean hasVendorId() { return fieldSetFlags()[0]; } /** * Clears the value of the 'vendorId' field. * @return This builder. */ public schemaregistry.RideRecordCompatible.Builder clearVendorId() { vendorId = null; fieldSetFlags()[0] = false; return this; } /** * Gets the value of the 'passenger_count' field. * @return The value. */ public int getPassengerCount() { return passenger_count; } /** * Sets the value of the 'passenger_count' field. * @param value The value of 'passenger_count'. * @return This builder. */ public schemaregistry.RideRecordCompatible.Builder setPassengerCount(int value) { validate(fields()[1], value); this.passenger_count = value; fieldSetFlags()[1] = true; return this; } /** * Checks whether the 'passenger_count' field has been set. * @return True if the 'passenger_count' field has been set, false otherwise. */ public boolean hasPassengerCount() { return fieldSetFlags()[1]; } /** * Clears the value of the 'passenger_count' field. * @return This builder. */ public schemaregistry.RideRecordCompatible.Builder clearPassengerCount() { fieldSetFlags()[1] = false; return this; } /** * Gets the value of the 'trip_distance' field. * @return The value. */ public double getTripDistance() { return trip_distance; } /** * Sets the value of the 'trip_distance' field. * @param value The value of 'trip_distance'. * @return This builder. */ public schemaregistry.RideRecordCompatible.Builder setTripDistance(double value) { validate(fields()[2], value); this.trip_distance = value; fieldSetFlags()[2] = true; return this; } /** * Checks whether the 'trip_distance' field has been set. * @return True if the 'trip_distance' field has been set, false otherwise. */ public boolean hasTripDistance() { return fieldSetFlags()[2]; } /** * Clears the value of the 'trip_distance' field. * @return This builder. */ public schemaregistry.RideRecordCompatible.Builder clearTripDistance() { fieldSetFlags()[2] = false; return this; } /** * Gets the value of the 'pu_location_id' field. * @return The value. */ public java.lang.Long getPuLocationId() { return pu_location_id; } /** * Sets the value of the 'pu_location_id' field. * @param value The value of 'pu_location_id'. * @return This builder. */ public schemaregistry.RideRecordCompatible.Builder setPuLocationId(java.lang.Long value) { validate(fields()[3], value); this.pu_location_id = value; fieldSetFlags()[3] = true; return this; } /** * Checks whether the 'pu_location_id' field has been set. * @return True if the 'pu_location_id' field has been set, false otherwise. */ public boolean hasPuLocationId() { return fieldSetFlags()[3]; } /** * Clears the value of the 'pu_location_id' field. * @return This builder. */ public schemaregistry.RideRecordCompatible.Builder clearPuLocationId() { pu_location_id = null; fieldSetFlags()[3] = false; return this; } @Override @SuppressWarnings("unchecked") public RideRecordCompatible build() { try { RideRecordCompatible record = new RideRecordCompatible(); record.vendorId = fieldSetFlags()[0] ? this.vendorId : (java.lang.String) defaultValue(fields()[0]); record.passenger_count = fieldSetFlags()[1] ? this.passenger_count : (java.lang.Integer) defaultValue(fields()[1]); record.trip_distance = fieldSetFlags()[2] ? this.trip_distance : (java.lang.Double) defaultValue(fields()[2]); record.pu_location_id = fieldSetFlags()[3] ? this.pu_location_id : (java.lang.Long) defaultValue(fields()[3]); return record; } catch (org.apache.avro.AvroMissingFieldException e) { throw e; } catch (java.lang.Exception e) { throw new org.apache.avro.AvroRuntimeException(e); } } } @SuppressWarnings("unchecked") private static final org.apache.avro.io.DatumWriter<RideRecordCompatible> WRITER$ = (org.apache.avro.io.DatumWriter<RideRecordCompatible>)MODEL$.createDatumWriter(SCHEMA$); @Override public void writeExternal(java.io.ObjectOutput out) throws java.io.IOException { WRITER$.write(this, SpecificData.getEncoder(out)); } @SuppressWarnings("unchecked") private static final org.apache.avro.io.DatumReader<RideRecordCompatible> READER$ = (org.apache.avro.io.DatumReader<RideRecordCompatible>)MODEL$.createDatumReader(SCHEMA$); @Override public void readExternal(java.io.ObjectInput in) throws java.io.IOException { READER$.read(this, SpecificData.getDecoder(in)); } @Override protected boolean hasCustomCoders() { return true; } @Override public void customEncode(org.apache.avro.io.Encoder out) throws java.io.IOException { out.writeString(this.vendorId); out.writeInt(this.passenger_count); out.writeDouble(this.trip_distance); if (this.pu_location_id == null) { out.writeIndex(0); out.writeNull(); } else { out.writeIndex(1); out.writeLong(this.pu_location_id); } } @Override public void customDecode(org.apache.avro.io.ResolvingDecoder in) throws java.io.IOException { org.apache.avro.Schema.Field[] fieldOrder = in.readFieldOrderIfDiff(); if (fieldOrder == null) { this.vendorId = in.readString(); this.passenger_count = in.readInt(); this.trip_distance = in.readDouble(); if (in.readIndex() != 1) { in.readNull(); this.pu_location_id = null; } else { this.pu_location_id = in.readLong(); } } else { for (int i = 0; i < 4; i++) { switch (fieldOrder[i].pos()) { case 0: this.vendorId = in.readString(); break; case 1: this.passenger_count = in.readInt(); break; case 2: this.trip_distance = in.readDouble(); break; case 3: if (in.readIndex() != 1) { in.readNull(); this.pu_location_id = null; } else { this.pu_location_id = in.readLong(); } break; default: throw new java.io.IOException("Corrupt ResolvingDecoder."); } } } } }
30.317073
462
0.657858
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
/** * Autogenerated by Avro * * DO NOT EDIT DIRECTLY */ package schemaregistry; import org.apache.avro.generic.GenericArray; import org.apache.avro.specific.SpecificData; import org.apache.avro.util.Utf8; import org.apache.avro.message.BinaryMessageEncoder; import org.apache.avro.message.BinaryMessageDecoder; import org.apache.avro.message.SchemaStore; @org.apache.avro.specific.AvroGenerated public class RideRecordNoneCompatible extends org.apache.avro.specific.SpecificRecordBase implements org.apache.avro.specific.SpecificRecord { private static final long serialVersionUID = -4618980179396772493L; public static final org.apache.avro.Schema SCHEMA$ = new org.apache.avro.Schema.Parser().parse("{\"type\":\"record\",\"name\":\"RideRecordNoneCompatible\",\"namespace\":\"schemaregistry\",\"fields\":[{\"name\":\"vendorId\",\"type\":\"int\"},{\"name\":\"passenger_count\",\"type\":\"int\"},{\"name\":\"trip_distance\",\"type\":\"double\"}]}"); public static org.apache.avro.Schema getClassSchema() { return SCHEMA$; } private static final SpecificData MODEL$ = new SpecificData(); private static final BinaryMessageEncoder<RideRecordNoneCompatible> ENCODER = new BinaryMessageEncoder<>(MODEL$, SCHEMA$); private static final BinaryMessageDecoder<RideRecordNoneCompatible> DECODER = new BinaryMessageDecoder<>(MODEL$, SCHEMA$); /** * Return the BinaryMessageEncoder instance used by this class. * @return the message encoder used by this class */ public static BinaryMessageEncoder<RideRecordNoneCompatible> getEncoder() { return ENCODER; } /** * Return the BinaryMessageDecoder instance used by this class. * @return the message decoder used by this class */ public static BinaryMessageDecoder<RideRecordNoneCompatible> getDecoder() { return DECODER; } /** * Create a new BinaryMessageDecoder instance for this class that uses the specified {@link SchemaStore}. * @param resolver a {@link SchemaStore} used to find schemas by fingerprint * @return a BinaryMessageDecoder instance for this class backed by the given SchemaStore */ public static BinaryMessageDecoder<RideRecordNoneCompatible> createDecoder(SchemaStore resolver) { return new BinaryMessageDecoder<>(MODEL$, SCHEMA$, resolver); } /** * Serializes this RideRecordNoneCompatible to a ByteBuffer. * @return a buffer holding the serialized data for this instance * @throws java.io.IOException if this instance could not be serialized */ public java.nio.ByteBuffer toByteBuffer() throws java.io.IOException { return ENCODER.encode(this); } /** * Deserializes a RideRecordNoneCompatible from a ByteBuffer. * @param b a byte buffer holding serialized data for an instance of this class * @return a RideRecordNoneCompatible instance decoded from the given buffer * @throws java.io.IOException if the given bytes could not be deserialized into an instance of this class */ public static RideRecordNoneCompatible fromByteBuffer( java.nio.ByteBuffer b) throws java.io.IOException { return DECODER.decode(b); } private int vendorId; private int passenger_count; private double trip_distance; /** * Default constructor. Note that this does not initialize fields * to their default values from the schema. If that is desired then * one should use <code>newBuilder()</code>. */ public RideRecordNoneCompatible() {} /** * All-args constructor. * @param vendorId The new value for vendorId * @param passenger_count The new value for passenger_count * @param trip_distance The new value for trip_distance */ public RideRecordNoneCompatible(java.lang.Integer vendorId, java.lang.Integer passenger_count, java.lang.Double trip_distance) { this.vendorId = vendorId; this.passenger_count = passenger_count; this.trip_distance = trip_distance; } @Override public org.apache.avro.specific.SpecificData getSpecificData() { return MODEL$; } @Override public org.apache.avro.Schema getSchema() { return SCHEMA$; } // Used by DatumWriter. Applications should not call. @Override public java.lang.Object get(int field$) { switch (field$) { case 0: return vendorId; case 1: return passenger_count; case 2: return trip_distance; default: throw new IndexOutOfBoundsException("Invalid index: " + field$); } } // Used by DatumReader. Applications should not call. @Override @SuppressWarnings(value="unchecked") public void put(int field$, java.lang.Object value$) { switch (field$) { case 0: vendorId = (java.lang.Integer)value$; break; case 1: passenger_count = (java.lang.Integer)value$; break; case 2: trip_distance = (java.lang.Double)value$; break; default: throw new IndexOutOfBoundsException("Invalid index: " + field$); } } /** * Gets the value of the 'vendorId' field. * @return The value of the 'vendorId' field. */ public int getVendorId() { return vendorId; } /** * Sets the value of the 'vendorId' field. * @param value the value to set. */ public void setVendorId(int value) { this.vendorId = value; } /** * Gets the value of the 'passenger_count' field. * @return The value of the 'passenger_count' field. */ public int getPassengerCount() { return passenger_count; } /** * Sets the value of the 'passenger_count' field. * @param value the value to set. */ public void setPassengerCount(int value) { this.passenger_count = value; } /** * Gets the value of the 'trip_distance' field. * @return The value of the 'trip_distance' field. */ public double getTripDistance() { return trip_distance; } /** * Sets the value of the 'trip_distance' field. * @param value the value to set. */ public void setTripDistance(double value) { this.trip_distance = value; } /** * Creates a new RideRecordNoneCompatible RecordBuilder. * @return A new RideRecordNoneCompatible RecordBuilder */ public static schemaregistry.RideRecordNoneCompatible.Builder newBuilder() { return new schemaregistry.RideRecordNoneCompatible.Builder(); } /** * Creates a new RideRecordNoneCompatible RecordBuilder by copying an existing Builder. * @param other The existing builder to copy. * @return A new RideRecordNoneCompatible RecordBuilder */ public static schemaregistry.RideRecordNoneCompatible.Builder newBuilder(schemaregistry.RideRecordNoneCompatible.Builder other) { if (other == null) { return new schemaregistry.RideRecordNoneCompatible.Builder(); } else { return new schemaregistry.RideRecordNoneCompatible.Builder(other); } } /** * Creates a new RideRecordNoneCompatible RecordBuilder by copying an existing RideRecordNoneCompatible instance. * @param other The existing instance to copy. * @return A new RideRecordNoneCompatible RecordBuilder */ public static schemaregistry.RideRecordNoneCompatible.Builder newBuilder(schemaregistry.RideRecordNoneCompatible other) { if (other == null) { return new schemaregistry.RideRecordNoneCompatible.Builder(); } else { return new schemaregistry.RideRecordNoneCompatible.Builder(other); } } /** * RecordBuilder for RideRecordNoneCompatible instances. */ @org.apache.avro.specific.AvroGenerated public static class Builder extends org.apache.avro.specific.SpecificRecordBuilderBase<RideRecordNoneCompatible> implements org.apache.avro.data.RecordBuilder<RideRecordNoneCompatible> { private int vendorId; private int passenger_count; private double trip_distance; /** Creates a new Builder */ private Builder() { super(SCHEMA$, MODEL$); } /** * Creates a Builder by copying an existing Builder. * @param other The existing Builder to copy. */ private Builder(schemaregistry.RideRecordNoneCompatible.Builder other) { super(other); if (isValidValue(fields()[0], other.vendorId)) { this.vendorId = data().deepCopy(fields()[0].schema(), other.vendorId); fieldSetFlags()[0] = other.fieldSetFlags()[0]; } if (isValidValue(fields()[1], other.passenger_count)) { this.passenger_count = data().deepCopy(fields()[1].schema(), other.passenger_count); fieldSetFlags()[1] = other.fieldSetFlags()[1]; } if (isValidValue(fields()[2], other.trip_distance)) { this.trip_distance = data().deepCopy(fields()[2].schema(), other.trip_distance); fieldSetFlags()[2] = other.fieldSetFlags()[2]; } } /** * Creates a Builder by copying an existing RideRecordNoneCompatible instance * @param other The existing instance to copy. */ private Builder(schemaregistry.RideRecordNoneCompatible other) { super(SCHEMA$, MODEL$); if (isValidValue(fields()[0], other.vendorId)) { this.vendorId = data().deepCopy(fields()[0].schema(), other.vendorId); fieldSetFlags()[0] = true; } if (isValidValue(fields()[1], other.passenger_count)) { this.passenger_count = data().deepCopy(fields()[1].schema(), other.passenger_count); fieldSetFlags()[1] = true; } if (isValidValue(fields()[2], other.trip_distance)) { this.trip_distance = data().deepCopy(fields()[2].schema(), other.trip_distance); fieldSetFlags()[2] = true; } } /** * Gets the value of the 'vendorId' field. * @return The value. */ public int getVendorId() { return vendorId; } /** * Sets the value of the 'vendorId' field. * @param value The value of 'vendorId'. * @return This builder. */ public schemaregistry.RideRecordNoneCompatible.Builder setVendorId(int value) { validate(fields()[0], value); this.vendorId = value; fieldSetFlags()[0] = true; return this; } /** * Checks whether the 'vendorId' field has been set. * @return True if the 'vendorId' field has been set, false otherwise. */ public boolean hasVendorId() { return fieldSetFlags()[0]; } /** * Clears the value of the 'vendorId' field. * @return This builder. */ public schemaregistry.RideRecordNoneCompatible.Builder clearVendorId() { fieldSetFlags()[0] = false; return this; } /** * Gets the value of the 'passenger_count' field. * @return The value. */ public int getPassengerCount() { return passenger_count; } /** * Sets the value of the 'passenger_count' field. * @param value The value of 'passenger_count'. * @return This builder. */ public schemaregistry.RideRecordNoneCompatible.Builder setPassengerCount(int value) { validate(fields()[1], value); this.passenger_count = value; fieldSetFlags()[1] = true; return this; } /** * Checks whether the 'passenger_count' field has been set. * @return True if the 'passenger_count' field has been set, false otherwise. */ public boolean hasPassengerCount() { return fieldSetFlags()[1]; } /** * Clears the value of the 'passenger_count' field. * @return This builder. */ public schemaregistry.RideRecordNoneCompatible.Builder clearPassengerCount() { fieldSetFlags()[1] = false; return this; } /** * Gets the value of the 'trip_distance' field. * @return The value. */ public double getTripDistance() { return trip_distance; } /** * Sets the value of the 'trip_distance' field. * @param value The value of 'trip_distance'. * @return This builder. */ public schemaregistry.RideRecordNoneCompatible.Builder setTripDistance(double value) { validate(fields()[2], value); this.trip_distance = value; fieldSetFlags()[2] = true; return this; } /** * Checks whether the 'trip_distance' field has been set. * @return True if the 'trip_distance' field has been set, false otherwise. */ public boolean hasTripDistance() { return fieldSetFlags()[2]; } /** * Clears the value of the 'trip_distance' field. * @return This builder. */ public schemaregistry.RideRecordNoneCompatible.Builder clearTripDistance() { fieldSetFlags()[2] = false; return this; } @Override @SuppressWarnings("unchecked") public RideRecordNoneCompatible build() { try { RideRecordNoneCompatible record = new RideRecordNoneCompatible(); record.vendorId = fieldSetFlags()[0] ? this.vendorId : (java.lang.Integer) defaultValue(fields()[0]); record.passenger_count = fieldSetFlags()[1] ? this.passenger_count : (java.lang.Integer) defaultValue(fields()[1]); record.trip_distance = fieldSetFlags()[2] ? this.trip_distance : (java.lang.Double) defaultValue(fields()[2]); return record; } catch (org.apache.avro.AvroMissingFieldException e) { throw e; } catch (java.lang.Exception e) { throw new org.apache.avro.AvroRuntimeException(e); } } } @SuppressWarnings("unchecked") private static final org.apache.avro.io.DatumWriter<RideRecordNoneCompatible> WRITER$ = (org.apache.avro.io.DatumWriter<RideRecordNoneCompatible>)MODEL$.createDatumWriter(SCHEMA$); @Override public void writeExternal(java.io.ObjectOutput out) throws java.io.IOException { WRITER$.write(this, SpecificData.getEncoder(out)); } @SuppressWarnings("unchecked") private static final org.apache.avro.io.DatumReader<RideRecordNoneCompatible> READER$ = (org.apache.avro.io.DatumReader<RideRecordNoneCompatible>)MODEL$.createDatumReader(SCHEMA$); @Override public void readExternal(java.io.ObjectInput in) throws java.io.IOException { READER$.read(this, SpecificData.getDecoder(in)); } @Override protected boolean hasCustomCoders() { return true; } @Override public void customEncode(org.apache.avro.io.Encoder out) throws java.io.IOException { out.writeInt(this.vendorId); out.writeInt(this.passenger_count); out.writeDouble(this.trip_distance); } @Override public void customDecode(org.apache.avro.io.ResolvingDecoder in) throws java.io.IOException { org.apache.avro.Schema.Field[] fieldOrder = in.readFieldOrderIfDiff(); if (fieldOrder == null) { this.vendorId = in.readInt(); this.passenger_count = in.readInt(); this.trip_distance = in.readDouble(); } else { for (int i = 0; i < 3; i++) { switch (fieldOrder[i].pos()) { case 0: this.vendorId = in.readInt(); break; case 1: this.passenger_count = in.readInt(); break; case 2: this.trip_distance = in.readDouble(); break; default: throw new java.io.IOException("Corrupt ResolvingDecoder."); } } } } }
30.607966
344
0.675975
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example; import com.opencsv.CSVReader; import com.opencsv.exceptions.CsvException; import io.confluent.kafka.serializers.AbstractKafkaAvroSerDeConfig; import io.confluent.kafka.serializers.KafkaAvroSerializer; import org.apache.kafka.clients.producer.KafkaProducer; import org.apache.kafka.clients.producer.ProducerConfig; import org.apache.kafka.clients.producer.ProducerRecord; import org.apache.kafka.streams.StreamsConfig; import schemaregistry.RideRecord; import java.io.FileReader; import java.io.IOException; import java.util.List; import java.util.Properties; import java.util.concurrent.ExecutionException; import java.util.stream.Collectors; public class AvroProducer { private Properties props = new Properties(); public AvroProducer() { props.put(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "pkc-75m1o.europe-west3.gcp.confluent.cloud:9092"); props.put("security.protocol", "SASL_SSL"); props.put("sasl.jaas.config", "org.apache.kafka.common.security.plain.PlainLoginModule required username='"+Secrets.KAFKA_CLUSTER_KEY+"' password='"+Secrets.KAFKA_CLUSTER_SECRET+"';"); props.put("sasl.mechanism", "PLAIN"); props.put("client.dns.lookup", "use_all_dns_ips"); props.put("session.timeout.ms", "45000"); props.put(ProducerConfig.ACKS_CONFIG, "all"); props.put(ProducerConfig.KEY_SERIALIZER_CLASS_CONFIG, "org.apache.kafka.common.serialization.StringSerializer"); props.put(ProducerConfig.VALUE_SERIALIZER_CLASS_CONFIG, KafkaAvroSerializer.class.getName()); props.put(AbstractKafkaAvroSerDeConfig.SCHEMA_REGISTRY_URL_CONFIG, "https://psrc-kk5gg.europe-west3.gcp.confluent.cloud"); props.put("basic.auth.credentials.source", "USER_INFO"); props.put("basic.auth.user.info", Secrets.SCHEMA_REGISTRY_KEY+":"+Secrets.SCHEMA_REGISTRY_SECRET); } public List<RideRecord> getRides() throws IOException, CsvException { var ridesStream = this.getClass().getResource("/rides.csv"); var reader = new CSVReader(new FileReader(ridesStream.getFile())); reader.skip(1); return reader.readAll().stream().map(row -> RideRecord.newBuilder() .setVendorId(row[0]) .setTripDistance(Double.parseDouble(row[4])) .setPassengerCount(Integer.parseInt(row[3])) .build() ).collect(Collectors.toList()); } public void publishRides(List<RideRecord> rides) throws ExecutionException, InterruptedException { KafkaProducer<String, RideRecord> kafkaProducer = new KafkaProducer<>(props); for (RideRecord ride : rides) { var record = kafkaProducer.send(new ProducerRecord<>("rides_avro", String.valueOf(ride.getVendorId()), ride), (metadata, exception) -> { if (exception != null) { System.out.println(exception.getMessage()); } }); System.out.println(record.get().offset()); Thread.sleep(500); } } public static void main(String[] args) throws IOException, CsvException, ExecutionException, InterruptedException { var producer = new AvroProducer(); var rideRecords = producer.getRides(); producer.publishRides(rideRecords); } }
44.767123
192
0.688323
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example; import org.apache.kafka.clients.consumer.ConsumerConfig; import org.apache.kafka.clients.consumer.ConsumerRecord; import org.apache.kafka.clients.consumer.KafkaConsumer; import org.apache.kafka.clients.producer.ProducerConfig; import org.example.data.Ride; import java.time.Duration; import java.time.temporal.ChronoUnit; import java.time.temporal.TemporalUnit; import java.util.List; import java.util.Properties; import io.confluent.kafka.serializers.KafkaJsonDeserializerConfig; public class JsonConsumer { private Properties props = new Properties(); private KafkaConsumer<String, Ride> consumer; public JsonConsumer() { props.put(ConsumerConfig.BOOTSTRAP_SERVERS_CONFIG, "pkc-75m1o.europe-west3.gcp.confluent.cloud:9092"); props.put("security.protocol", "SASL_SSL"); props.put("sasl.jaas.config", "org.apache.kafka.common.security.plain.PlainLoginModule required username='"+Secrets.KAFKA_CLUSTER_KEY+"' password='"+Secrets.KAFKA_CLUSTER_SECRET+"';"); props.put("sasl.mechanism", "PLAIN"); props.put("client.dns.lookup", "use_all_dns_ips"); props.put("session.timeout.ms", "45000"); props.put(ConsumerConfig.KEY_DESERIALIZER_CLASS_CONFIG, "org.apache.kafka.common.serialization.StringDeserializer"); props.put(ConsumerConfig.VALUE_DESERIALIZER_CLASS_CONFIG, "io.confluent.kafka.serializers.KafkaJsonDeserializer"); props.put(ConsumerConfig.GROUP_ID_CONFIG, "kafka_tutorial_example.jsonconsumer.v2"); props.put(ConsumerConfig.AUTO_OFFSET_RESET_CONFIG, "earliest"); props.put(KafkaJsonDeserializerConfig.JSON_VALUE_TYPE, Ride.class); consumer = new KafkaConsumer<String, Ride>(props); consumer.subscribe(List.of("rides")); } public void consumeFromKafka() { System.out.println("Consuming form kafka started"); var results = consumer.poll(Duration.of(1, ChronoUnit.SECONDS)); var i = 0; do { for(ConsumerRecord<String, Ride> result: results) { System.out.println(result.value().DOLocationID); } results = consumer.poll(Duration.of(1, ChronoUnit.SECONDS)); System.out.println("RESULTS:::" + results.count()); i++; } while(!results.isEmpty() || i < 10); } public static void main(String[] args) { JsonConsumer jsonConsumer = new JsonConsumer(); jsonConsumer.consumeFromKafka(); } }
42.631579
192
0.697104
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example; import org.apache.kafka.clients.consumer.ConsumerConfig; import org.apache.kafka.common.serialization.Serdes; import org.apache.kafka.streams.KafkaStreams; import org.apache.kafka.streams.StreamsBuilder; import org.apache.kafka.streams.StreamsConfig; import org.apache.kafka.streams.Topology; import org.apache.kafka.streams.kstream.Consumed; import org.apache.kafka.streams.kstream.Produced; import org.example.customserdes.CustomSerdes; import org.example.data.Ride; import java.util.Properties; public class JsonKStream { private Properties props = new Properties(); public JsonKStream() { props.put(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "pkc-75m1o.europe-west3.gcp.confluent.cloud:9092"); props.put("security.protocol", "SASL_SSL"); props.put("sasl.jaas.config", "org.apache.kafka.common.security.plain.PlainLoginModule required username='"+Secrets.KAFKA_CLUSTER_KEY+"' password='"+Secrets.KAFKA_CLUSTER_SECRET+"';"); props.put("sasl.mechanism", "PLAIN"); props.put("client.dns.lookup", "use_all_dns_ips"); props.put("session.timeout.ms", "45000"); props.put(StreamsConfig.APPLICATION_ID_CONFIG, "kafka_tutorial.kstream.count.plocation.v1"); props.put(ConsumerConfig.AUTO_OFFSET_RESET_CONFIG, "latest"); props.put(StreamsConfig.CACHE_MAX_BYTES_BUFFERING_CONFIG, 0); } public Topology createTopology() { StreamsBuilder streamsBuilder = new StreamsBuilder(); var ridesStream = streamsBuilder.stream("rides", Consumed.with(Serdes.String(), CustomSerdes.getSerde(Ride.class))); var puLocationCount = ridesStream.groupByKey().count().toStream(); puLocationCount.to("rides-pulocation-count", Produced.with(Serdes.String(), Serdes.Long())); return streamsBuilder.build(); } public void countPLocation() throws InterruptedException { var topology = createTopology(); var kStreams = new KafkaStreams(topology, props); kStreams.start(); while (kStreams.state() != KafkaStreams.State.RUNNING) { System.out.println(kStreams.state()); Thread.sleep(1000); } System.out.println(kStreams.state()); Runtime.getRuntime().addShutdownHook(new Thread(kStreams::close)); } public static void main(String[] args) throws InterruptedException { var object = new JsonKStream(); object.countPLocation(); } }
42.175439
192
0.707724
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example; import org.apache.kafka.clients.consumer.ConsumerConfig; import org.apache.kafka.common.serialization.Serdes; import org.apache.kafka.streams.KafkaStreams; import org.apache.kafka.streams.StreamsBuilder; import org.apache.kafka.streams.StreamsConfig; import org.apache.kafka.streams.Topology; import org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler; import org.apache.kafka.streams.kstream.*; import org.example.customserdes.CustomSerdes; import org.example.data.PickupLocation; import org.example.data.Ride; import org.example.data.VendorInfo; import java.time.Duration; import java.util.Optional; import java.util.Properties; public class JsonKStreamJoins { private Properties props = new Properties(); public JsonKStreamJoins() { props.put(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "pkc-75m1o.europe-west3.gcp.confluent.cloud:9092"); props.put("security.protocol", "SASL_SSL"); props.put("sasl.jaas.config", "org.apache.kafka.common.security.plain.PlainLoginModule required username='"+Secrets.KAFKA_CLUSTER_KEY+"' password='"+Secrets.KAFKA_CLUSTER_SECRET+"';"); props.put("sasl.mechanism", "PLAIN"); props.put("client.dns.lookup", "use_all_dns_ips"); props.put("session.timeout.ms", "45000"); props.put(StreamsConfig.APPLICATION_ID_CONFIG, "kafka_tutorial.kstream.joined.rides.pickuplocation.v1"); props.put(ConsumerConfig.AUTO_OFFSET_RESET_CONFIG, "latest"); props.put(StreamsConfig.CACHE_MAX_BYTES_BUFFERING_CONFIG, 0); } public Topology createTopology() { StreamsBuilder streamsBuilder = new StreamsBuilder(); KStream<String, Ride> rides = streamsBuilder.stream(Topics.INPUT_RIDE_TOPIC, Consumed.with(Serdes.String(), CustomSerdes.getSerde(Ride.class))); KStream<String, PickupLocation> pickupLocations = streamsBuilder.stream(Topics.INPUT_RIDE_LOCATION_TOPIC, Consumed.with(Serdes.String(), CustomSerdes.getSerde(PickupLocation.class))); var pickupLocationsKeyedOnPUId = pickupLocations.selectKey((key, value) -> String.valueOf(value.PULocationID)); var joined = rides.join(pickupLocationsKeyedOnPUId, (ValueJoiner<Ride, PickupLocation, Optional<VendorInfo>>) (ride, pickupLocation) -> { var period = Duration.between(ride.tpep_dropoff_datetime, pickupLocation.tpep_pickup_datetime); if (period.abs().toMinutes() > 10) return Optional.empty(); else return Optional.of(new VendorInfo(ride.VendorID, pickupLocation.PULocationID, pickupLocation.tpep_pickup_datetime, ride.tpep_dropoff_datetime)); }, JoinWindows.ofTimeDifferenceAndGrace(Duration.ofMinutes(20), Duration.ofMinutes(5)), StreamJoined.with(Serdes.String(), CustomSerdes.getSerde(Ride.class), CustomSerdes.getSerde(PickupLocation.class))); joined.filter(((key, value) -> value.isPresent())).mapValues(Optional::get) .to(Topics.OUTPUT_TOPIC, Produced.with(Serdes.String(), CustomSerdes.getSerde(VendorInfo.class))); return streamsBuilder.build(); } public void joinRidesPickupLocation() throws InterruptedException { var topology = createTopology(); var kStreams = new KafkaStreams(topology, props); kStreams.setUncaughtExceptionHandler(exception -> { System.out.println(exception.getMessage()); return StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse.SHUTDOWN_APPLICATION; }); kStreams.start(); while (kStreams.state() != KafkaStreams.State.RUNNING) { System.out.println(kStreams.state()); Thread.sleep(1000); } System.out.println(kStreams.state()); Runtime.getRuntime().addShutdownHook(new Thread(kStreams::close)); } public static void main(String[] args) throws InterruptedException { var object = new JsonKStreamJoins(); object.joinRidesPickupLocation(); } }
50.922078
192
0.718039
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example; import org.apache.kafka.clients.consumer.ConsumerConfig; import org.apache.kafka.common.serialization.Serdes; import org.apache.kafka.streams.KafkaStreams; import org.apache.kafka.streams.StreamsBuilder; import org.apache.kafka.streams.StreamsConfig; import org.apache.kafka.streams.Topology; import org.apache.kafka.streams.kstream.Consumed; import org.apache.kafka.streams.kstream.Produced; import org.apache.kafka.streams.kstream.TimeWindows; import org.apache.kafka.streams.kstream.WindowedSerdes; import org.example.customserdes.CustomSerdes; import org.example.data.Ride; import java.time.Duration; import java.time.temporal.ChronoUnit; import java.util.Properties; public class JsonKStreamWindow { private Properties props = new Properties(); public JsonKStreamWindow() { props.put(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "pkc-75m1o.europe-west3.gcp.confluent.cloud:9092"); props.put("security.protocol", "SASL_SSL"); props.put("sasl.jaas.config", "org.apache.kafka.common.security.plain.PlainLoginModule required username='"+Secrets.KAFKA_CLUSTER_KEY+"' password='"+Secrets.KAFKA_CLUSTER_SECRET+"';"); props.put("sasl.mechanism", "PLAIN"); props.put("client.dns.lookup", "use_all_dns_ips"); props.put("session.timeout.ms", "45000"); props.put(StreamsConfig.APPLICATION_ID_CONFIG, "kafka_tutorial.kstream.count.plocation.v1"); props.put(ConsumerConfig.AUTO_OFFSET_RESET_CONFIG, "latest"); props.put(StreamsConfig.CACHE_MAX_BYTES_BUFFERING_CONFIG, 0); } public Topology createTopology() { StreamsBuilder streamsBuilder = new StreamsBuilder(); var ridesStream = streamsBuilder.stream("rides", Consumed.with(Serdes.String(), CustomSerdes.getSerde(Ride.class))); var puLocationCount = ridesStream.groupByKey() .windowedBy(TimeWindows.ofSizeAndGrace(Duration.ofSeconds(10), Duration.ofSeconds(5))) .count().toStream(); var windowSerde = WindowedSerdes.timeWindowedSerdeFrom(String.class, 10*1000); puLocationCount.to("rides-pulocation-window-count", Produced.with(windowSerde, Serdes.Long())); return streamsBuilder.build(); } public void countPLocationWindowed() { var topology = createTopology(); var kStreams = new KafkaStreams(topology, props); kStreams.start(); Runtime.getRuntime().addShutdownHook(new Thread(kStreams::close)); } public static void main(String[] args) { var object = new JsonKStreamWindow(); object.countPLocationWindowed(); } }
41.983607
192
0.724151
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example; import com.opencsv.CSVReader; import com.opencsv.exceptions.CsvException; import org.apache.kafka.clients.producer.*; import org.apache.kafka.streams.StreamsConfig; import org.example.data.Ride; import java.io.FileReader; import java.io.IOException; import java.time.LocalDateTime; import java.util.List; import java.util.Properties; import java.util.concurrent.ExecutionException; import java.util.stream.Collectors; public class JsonProducer { private Properties props = new Properties(); public JsonProducer() { props.put(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "pkc-75m1o.europe-west3.gcp.confluent.cloud:9092"); props.put("security.protocol", "SASL_SSL"); props.put("sasl.jaas.config", "org.apache.kafka.common.security.plain.PlainLoginModule required username='"+Secrets.KAFKA_CLUSTER_KEY+"' password='"+Secrets.KAFKA_CLUSTER_SECRET+"';"); props.put("sasl.mechanism", "PLAIN"); props.put("client.dns.lookup", "use_all_dns_ips"); props.put("session.timeout.ms", "45000"); props.put(ProducerConfig.ACKS_CONFIG, "all"); props.put(ProducerConfig.KEY_SERIALIZER_CLASS_CONFIG, "org.apache.kafka.common.serialization.StringSerializer"); props.put(ProducerConfig.VALUE_SERIALIZER_CLASS_CONFIG, "io.confluent.kafka.serializers.KafkaJsonSerializer"); } public List<Ride> getRides() throws IOException, CsvException { var ridesStream = this.getClass().getResource("/rides.csv"); var reader = new CSVReader(new FileReader(ridesStream.getFile())); reader.skip(1); return reader.readAll().stream().map(arr -> new Ride(arr)) .collect(Collectors.toList()); } public void publishRides(List<Ride> rides) throws ExecutionException, InterruptedException { KafkaProducer<String, Ride> kafkaProducer = new KafkaProducer<String, Ride>(props); for(Ride ride: rides) { ride.tpep_pickup_datetime = LocalDateTime.now().minusMinutes(20); ride.tpep_dropoff_datetime = LocalDateTime.now(); var record = kafkaProducer.send(new ProducerRecord<>("rides", String.valueOf(ride.DOLocationID), ride), (metadata, exception) -> { if(exception != null) { System.out.println(exception.getMessage()); } }); System.out.println(record.get().offset()); System.out.println(ride.DOLocationID); Thread.sleep(500); } } public static void main(String[] args) throws IOException, CsvException, ExecutionException, InterruptedException { var producer = new JsonProducer(); var rides = producer.getRides(); producer.publishRides(rides); } }
44.278689
192
0.682361
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example; import com.opencsv.exceptions.CsvException; import org.apache.kafka.clients.producer.KafkaProducer; import org.apache.kafka.clients.producer.ProducerConfig; import org.apache.kafka.clients.producer.ProducerRecord; import org.example.data.PickupLocation; import java.io.IOException; import java.time.LocalDateTime; import java.util.Properties; import java.util.concurrent.ExecutionException; public class JsonProducerPickupLocation { private Properties props = new Properties(); public JsonProducerPickupLocation() { props.put(ProducerConfig.BOOTSTRAP_SERVERS_CONFIG, "pkc-75m1o.europe-west3.gcp.confluent.cloud:9092"); props.put("security.protocol", "SASL_SSL"); props.put("sasl.jaas.config", "org.apache.kafka.common.security.plain.PlainLoginModule required username='"+Secrets.KAFKA_CLUSTER_KEY+"' password='"+Secrets.KAFKA_CLUSTER_SECRET+"';"); props.put("sasl.mechanism", "PLAIN"); props.put("client.dns.lookup", "use_all_dns_ips"); props.put("session.timeout.ms", "45000"); props.put(ProducerConfig.ACKS_CONFIG, "all"); props.put(ProducerConfig.KEY_SERIALIZER_CLASS_CONFIG, "org.apache.kafka.common.serialization.StringSerializer"); props.put(ProducerConfig.VALUE_SERIALIZER_CLASS_CONFIG, "io.confluent.kafka.serializers.KafkaJsonSerializer"); } public void publish(PickupLocation pickupLocation) throws ExecutionException, InterruptedException { KafkaProducer<String, PickupLocation> kafkaProducer = new KafkaProducer<String, PickupLocation>(props); var record = kafkaProducer.send(new ProducerRecord<>("rides_location", String.valueOf(pickupLocation.PULocationID), pickupLocation), (metadata, exception) -> { if (exception != null) { System.out.println(exception.getMessage()); } }); System.out.println(record.get().offset()); } public static void main(String[] args) throws IOException, CsvException, ExecutionException, InterruptedException { var producer = new JsonProducerPickupLocation(); producer.publish(new PickupLocation(186, LocalDateTime.now())); } }
47.577778
192
0.730892
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example; public class Secrets { public static final String KAFKA_CLUSTER_KEY = "REPLACE_WITH_YOUR_KAFKA_CLUSTER_KEY"; public static final String KAFKA_CLUSTER_SECRET = "REPLACE_WITH_YOUR_KAFKA_CLUSTER_SECRET"; public static final String SCHEMA_REGISTRY_KEY = "REPLACE_WITH_SCHEMA_REGISTRY_KEY"; public static final String SCHEMA_REGISTRY_SECRET = "REPLACE_WITH_SCHEMA_REGISTRY_SECRET"; }
37.181818
95
0.761337
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example; public class Topics { public static final String INPUT_RIDE_TOPIC = "rides"; public static final String INPUT_RIDE_LOCATION_TOPIC = "rides_location"; public static final String OUTPUT_TOPIC = "vendor_info"; }
29.5
76
0.73251
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example.customserdes; import io.confluent.kafka.serializers.AbstractKafkaAvroSerDeConfig; import io.confluent.kafka.serializers.KafkaJsonDeserializer; import io.confluent.kafka.serializers.KafkaJsonSerializer; import io.confluent.kafka.streams.serdes.avro.SpecificAvroSerde; import org.apache.avro.specific.SpecificRecordBase; import org.apache.kafka.common.serialization.Deserializer; import org.apache.kafka.common.serialization.Serde; import org.apache.kafka.common.serialization.Serdes; import org.apache.kafka.common.serialization.Serializer; import org.example.data.PickupLocation; import org.example.data.Ride; import org.example.data.VendorInfo; import java.util.HashMap; import java.util.Map; public class CustomSerdes { public static <T> Serde<T> getSerde(Class<T> classOf) { Map<String, Object> serdeProps = new HashMap<>(); serdeProps.put("json.value.type", classOf); final Serializer<T> mySerializer = new KafkaJsonSerializer<>(); mySerializer.configure(serdeProps, false); final Deserializer<T> myDeserializer = new KafkaJsonDeserializer<>(); myDeserializer.configure(serdeProps, false); return Serdes.serdeFrom(mySerializer, myDeserializer); } public static <T extends SpecificRecordBase> SpecificAvroSerde getAvroSerde(boolean isKey, String schemaRegistryUrl) { var serde = new SpecificAvroSerde<T>(); Map<String, Object> serdeProps = new HashMap<>(); serdeProps.put(AbstractKafkaAvroSerDeConfig.SCHEMA_REGISTRY_URL_CONFIG, schemaRegistryUrl); serde.configure(serdeProps, isKey); return serde; } }
37.325581
122
0.763206
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example.data; import java.time.LocalDateTime; public class PickupLocation { public PickupLocation(long PULocationID, LocalDateTime tpep_pickup_datetime) { this.PULocationID = PULocationID; this.tpep_pickup_datetime = tpep_pickup_datetime; } public PickupLocation() { } public long PULocationID; public LocalDateTime tpep_pickup_datetime; }
22.352941
82
0.724747
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example.data; import java.nio.DoubleBuffer; import java.time.LocalDate; import java.time.LocalDateTime; import java.time.format.DateTimeFormatter; public class Ride { public Ride(String[] arr) { VendorID = arr[0]; tpep_pickup_datetime = LocalDateTime.parse(arr[1], DateTimeFormatter.ofPattern("yyyy-MM-dd HH:mm:ss")); tpep_dropoff_datetime = LocalDateTime.parse(arr[2], DateTimeFormatter.ofPattern("yyyy-MM-dd HH:mm:ss")); passenger_count = Integer.parseInt(arr[3]); trip_distance = Double.parseDouble(arr[4]); RatecodeID = Long.parseLong(arr[5]); store_and_fwd_flag = arr[6]; PULocationID = Long.parseLong(arr[7]); DOLocationID = Long.parseLong(arr[8]); payment_type = arr[9]; fare_amount = Double.parseDouble(arr[10]); extra = Double.parseDouble(arr[11]); mta_tax = Double.parseDouble(arr[12]); tip_amount = Double.parseDouble(arr[13]); tolls_amount = Double.parseDouble(arr[14]); improvement_surcharge = Double.parseDouble(arr[15]); total_amount = Double.parseDouble(arr[16]); congestion_surcharge = Double.parseDouble(arr[17]); } public Ride(){} public String VendorID; public LocalDateTime tpep_pickup_datetime; public LocalDateTime tpep_dropoff_datetime; public int passenger_count; public double trip_distance; public long RatecodeID; public String store_and_fwd_flag; public long PULocationID; public long DOLocationID; public String payment_type; public double fare_amount; public double extra; public double mta_tax; public double tip_amount; public double tolls_amount; public double improvement_surcharge; public double total_amount; public double congestion_surcharge; }
35.56
112
0.681445
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example.data; import java.time.LocalDateTime; public class VendorInfo { public VendorInfo(String vendorID, long PULocationID, LocalDateTime pickupTime, LocalDateTime lastDropoffTime) { VendorID = vendorID; this.PULocationID = PULocationID; this.pickupTime = pickupTime; this.lastDropoffTime = lastDropoffTime; } public VendorInfo() { } public String VendorID; public long PULocationID; public LocalDateTime pickupTime; public LocalDateTime lastDropoffTime; }
23.590909
116
0.72037
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example; import org.apache.kafka.clients.consumer.ConsumerConfig; import org.apache.kafka.common.internals.Topic; import org.apache.kafka.common.serialization.Serdes; import org.apache.kafka.streams.*; import org.example.customserdes.CustomSerdes; import org.example.data.PickupLocation; import org.example.data.Ride; import org.example.data.VendorInfo; import org.example.helper.DataGeneratorHelper; import org.junit.jupiter.api.AfterAll; import org.junit.jupiter.api.BeforeEach; import org.junit.jupiter.api.Test; import javax.xml.crypto.Data; import java.util.Properties; import static org.junit.jupiter.api.Assertions.*; class JsonKStreamJoinsTest { private Properties props = new Properties(); private static TopologyTestDriver testDriver; private TestInputTopic<String, Ride> ridesTopic; private TestInputTopic<String, PickupLocation> pickLocationTopic; private TestOutputTopic<String, VendorInfo> outputTopic; private Topology topology = new JsonKStreamJoins().createTopology(); @BeforeEach public void setup() { props = new Properties(); props.setProperty(StreamsConfig.APPLICATION_ID_CONFIG, "testing_count_application"); props.setProperty(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "dummy:1234"); if (testDriver != null) { testDriver.close(); } testDriver = new TopologyTestDriver(topology, props); ridesTopic = testDriver.createInputTopic(Topics.INPUT_RIDE_TOPIC, Serdes.String().serializer(), CustomSerdes.getSerde(Ride.class).serializer()); pickLocationTopic = testDriver.createInputTopic(Topics.INPUT_RIDE_LOCATION_TOPIC, Serdes.String().serializer(), CustomSerdes.getSerde(PickupLocation.class).serializer()); outputTopic = testDriver.createOutputTopic(Topics.OUTPUT_TOPIC, Serdes.String().deserializer(), CustomSerdes.getSerde(VendorInfo.class).deserializer()); } @Test public void testIfJoinWorksOnSameDropOffPickupLocationId() { Ride ride = DataGeneratorHelper.generateRide(); PickupLocation pickupLocation = DataGeneratorHelper.generatePickUpLocation(ride.DOLocationID); ridesTopic.pipeInput(String.valueOf(ride.DOLocationID), ride); pickLocationTopic.pipeInput(String.valueOf(pickupLocation.PULocationID), pickupLocation); assertEquals(outputTopic.getQueueSize(), 1); var expected = new VendorInfo(ride.VendorID, pickupLocation.PULocationID, pickupLocation.tpep_pickup_datetime, ride.tpep_dropoff_datetime); var result = outputTopic.readKeyValue(); assertEquals(result.key, String.valueOf(ride.DOLocationID)); assertEquals(result.value.VendorID, expected.VendorID); assertEquals(result.value.pickupTime, expected.pickupTime); } @AfterAll public static void shutdown() { testDriver.close(); } }
44.460317
178
0.754803
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example; import org.apache.kafka.common.serialization.Serdes; import org.apache.kafka.streams.*; import org.example.customserdes.CustomSerdes; import org.example.data.Ride; import org.example.helper.DataGeneratorHelper; import org.junit.jupiter.api.AfterAll; import org.junit.jupiter.api.BeforeEach; import org.junit.jupiter.api.Test; import static org.junit.jupiter.api.Assertions.*; import java.util.Properties; class JsonKStreamTest { private Properties props; private static TopologyTestDriver testDriver; private TestInputTopic<String, Ride> inputTopic; private TestOutputTopic<String, Long> outputTopic; private Topology topology = new JsonKStream().createTopology(); @BeforeEach public void setup() { props = new Properties(); props.setProperty(StreamsConfig.APPLICATION_ID_CONFIG, "testing_count_application"); props.setProperty(StreamsConfig.BOOTSTRAP_SERVERS_CONFIG, "dummy:1234"); if (testDriver != null) { testDriver.close(); } testDriver = new TopologyTestDriver(topology, props); inputTopic = testDriver.createInputTopic("rides", Serdes.String().serializer(), CustomSerdes.getSerde(Ride.class).serializer()); outputTopic = testDriver.createOutputTopic("rides-pulocation-count", Serdes.String().deserializer(), Serdes.Long().deserializer()); } @Test public void testIfOneMessageIsPassedToInputTopicWeGetCountOfOne() { Ride ride = DataGeneratorHelper.generateRide(); inputTopic.pipeInput(String.valueOf(ride.DOLocationID), ride); assertEquals(outputTopic.readKeyValue(), KeyValue.pair(String.valueOf(ride.DOLocationID), 1L)); assertTrue(outputTopic.isEmpty()); } @Test public void testIfTwoMessageArePassedWithDifferentKey() { Ride ride1 = DataGeneratorHelper.generateRide(); ride1.DOLocationID = 100L; inputTopic.pipeInput(String.valueOf(ride1.DOLocationID), ride1); Ride ride2 = DataGeneratorHelper.generateRide(); ride2.DOLocationID = 200L; inputTopic.pipeInput(String.valueOf(ride2.DOLocationID), ride2); assertEquals(outputTopic.readKeyValue(), KeyValue.pair(String.valueOf(ride1.DOLocationID), 1L)); assertEquals(outputTopic.readKeyValue(), KeyValue.pair(String.valueOf(ride2.DOLocationID), 1L)); assertTrue(outputTopic.isEmpty()); } @Test public void testIfTwoMessageArePassedWithSameKey() { Ride ride1 = DataGeneratorHelper.generateRide(); ride1.DOLocationID = 100L; inputTopic.pipeInput(String.valueOf(ride1.DOLocationID), ride1); Ride ride2 = DataGeneratorHelper.generateRide(); ride2.DOLocationID = 100L; inputTopic.pipeInput(String.valueOf(ride2.DOLocationID), ride2); assertEquals(outputTopic.readKeyValue(), KeyValue.pair("100", 1L)); assertEquals(outputTopic.readKeyValue(), KeyValue.pair("100", 2L)); assertTrue(outputTopic.isEmpty()); } @AfterAll public static void tearDown() { testDriver.close(); } }
37.7375
139
0.715623
data-engineering-zoomcamp
https://github.com/DataTalksClub/data-engineering-zoomcamp
Free Data Engineering course!
15,757
3,602
2023-12-05 01:08:47+00:00
2021-10-21 09:32:50+00:00
1,561
null
Java
package org.example.helper; import org.example.data.PickupLocation; import org.example.data.Ride; import org.example.data.VendorInfo; import java.time.LocalDateTime; import java.time.format.DateTimeFormatter; import java.util.List; public class DataGeneratorHelper { public static Ride generateRide() { var arrivalTime = LocalDateTime.now().format(DateTimeFormatter.ofPattern("yyyy-MM-dd HH:mm:ss")); var departureTime = LocalDateTime.now().minusMinutes(30).format(DateTimeFormatter.ofPattern("yyyy-MM-dd HH:mm:ss")); return new Ride(new String[]{"1", departureTime, arrivalTime,"1","1.50","1","N","238","75","2","8","0.5","0.5","0","0","0.3","9.3","0"}); } public static PickupLocation generatePickUpLocation(long pickupLocationId) { return new PickupLocation(pickupLocationId, LocalDateTime.now()); } }
38
145
0.715286
awesome-data-engineering
https://github.com/igorbarinov/awesome-data-engineering
A curated list of data engineering tools for software developers
5,457
1,029
2023-12-04 22:33:30+00:00
2015-06-18 19:39:42+00:00
226
Creative Commons Zero v1.0 Universal
Misc
name: CI on: pull_request: branches: [master] jobs: Awesome_Lint: runs-on: ubuntu-latest steps: - uses: actions/checkout@v2 with: fetch-depth: 0 - run: npx awesome-lint
15.615385
33
0.576744
awesome-data-engineering
https://github.com/igorbarinov/awesome-data-engineering
A curated list of data engineering tools for software developers
5,457
1,029
2023-12-04 22:33:30+00:00
2015-06-18 19:39:42+00:00
226
Creative Commons Zero v1.0 Universal
Misc
# Awesome Data Engineering [![Awesome](https://awesome.re/badge-flat2.svg)](https://github.com/sindresorhus/awesome) > A curated list of awesome things related to Data Engineering. ## Contents - [Databases](#databases) - [Data Ingestion](#data-ingestion) - [File System](#file-system) - [Serialization format](#serialization-format) - [Stream Processing](#stream-processing) - [Batch Processing](#batch-processing) - [Charts and Dashboards](#charts-and-dashboards) - [Workflow](#workflow) - [Data Lake Management](#data-lake-management) - [ELK Elastic Logstash Kibana](#elk-elastic-logstash-kibana) - [Docker](#docker) - [Datasets](#datasets) - [Realtime](#realtime) - [Data Dumps](#data-dumps) - [Monitoring](#monitoring) - [Prometheus](#prometheus) - [Testing](#testing) - [Community](#community) - [Forums](#forums) - [Conferences](#conferences) - [Podcasts](#podcasts) ## Databases - Relational - [RQLite](https://github.com/rqlite/rqlite) - Replicated SQLite using the Raft consensus protocol. - [MySQL](https://www.mysql.com/) - The world's most popular open source database. - [TiDB](https://github.com/pingcap/tidb) - TiDB is a distributed NewSQL database compatible with MySQL protocol. - [Percona XtraBackup](https://www.percona.com/software/mysql-database/percona-xtrabackup) - Percona XtraBackup is a free, open source, complete online backup solution for all versions of Percona Server, MySQL® and MariaDB®. - [mysql_utils](https://github.com/pinterest/mysql_utils) - Pinterest MySQL Management Tools. - [MariaDB](https://mariadb.org/) - An enhanced, drop-in replacement for MySQL. - [PostgreSQL](https://www.postgresql.org/) - The world's most advanced open source database. - [Amazon RDS](https://aws.amazon.com/rds/) - Amazon RDS makes it easy to set up, operate, and scale a relational database in the cloud. - [Crate.IO](https://crate.io/) - Scalable SQL database with the NOSQL goodies. - Key-Value - [Redis](https://redis.io/) - An open source, BSD licensed, advanced key-value cache and store. - [Riak](https://docs.basho.com/riak/kv/) - A distributed database designed to deliver maximum data availability by distributing data across multiple servers. - [AWS DynamoDB](https://aws.amazon.com/dynamodb/) - A fast and flexible NoSQL database service for all applications that need consistent, single-digit millisecond latency at any scale. - [HyperDex](https://github.com/rescrv/HyperDex) - HyperDex is a scalable, searchable key-value store. Deprecated. - [SSDB](https://ssdb.io) - A high performance NoSQL database supporting many data structures, an alternative to Redis. - [Kyoto Tycoon](https://github.com/alticelabs/kyoto) - Kyoto Tycoon is a lightweight network server on top of the Kyoto Cabinet key-value database, built for high-performance and concurrency. - [IonDB](https://github.com/iondbproject/iondb) - A key-value store for microcontroller and IoT applications. - Column - [Cassandra](https://cassandra.apache.org/) - The right choice when you need scalability and high availability without compromising performance. - [Cassandra Calculator](https://www.ecyrd.com/cassandracalculator/) - This simple form allows you to try out different values for your Apache Cassandra cluster and see what the impact is for your application. - [CCM](https://github.com/pcmanus/ccm) - A script to easily create and destroy an Apache Cassandra cluster on localhost. - [ScyllaDB](https://github.com/scylladb/scylla) - NoSQL data store using the seastar framework, compatible with Apache Cassandra. - [HBase](https://hbase.apache.org/) - The Hadoop database, a distributed, scalable, big data store. - [AWS Redshift](https://aws.amazon.com/redshift/) - A fast, fully managed, petabyte-scale data warehouse that makes it simple and cost-effective to analyze all your data using your existing business intelligence tools. - [FiloDB](https://github.com/filodb/FiloDB) - Distributed. Columnar. Versioned. Streaming. SQL. - [Vertica](https://www.vertica.com) - Distributed, MPP columnar database with extensive analytics SQL. - [ClickHouse](https://clickhouse.tech) - Distributed columnar DBMS for OLAP. SQL. - Document - [MongoDB](https://www.mongodb.com) - An open-source, document database designed for ease of development and scaling. - [Percona Server for MongoDB](https://www.percona.com/software/mongo-database/percona-server-for-mongodb) - Percona Server for MongoDB® is a free, enhanced, fully compatible, open source, drop-in replacement for the MongoDB® Community Edition that includes enterprise-grade features and functionality. - [MemDB](https://github.com/rain1017/memdb) - Distributed Transactional In-Memory Database (based on MongoDB). - [Elasticsearch](https://www.elastic.co/) - Search & Analyze Data in Real Time. - [Couchbase](https://www.couchbase.com/) - The highest performing NoSQL distributed database. - [RethinkDB](https://rethinkdb.com/) - The open-source database for the realtime web. - [RavenDB](https://ravendb.net/) - Fully Transactional NoSQL Document Database. - Graph - [Neo4j](https://neo4j.com/) - The world's leading graph database. - [OrientDB](https://orientdb.com) - 2nd Generation Distributed Graph Database with the flexibility of Documents in one product with an Open Source commercial friendly license. - [ArangoDB](https://www.arangodb.com/) - A distributed free and open-source database with a flexible data model for documents, graphs, and key-values. - [Titan](https://titan.thinkaurelius.com) - A scalable graph database optimized for storing and querying graphs containing hundreds of billions of vertices and edges distributed across a multi-machine cluster. - [FlockDB](https://github.com/twitter-archive/flockdb) - A distributed, fault-tolerant graph database by Twitter. Deprecated. - Distributed - [DAtomic](https://www.datomic.com) - The fully transactional, cloud-ready, distributed database. - [Apache Geode](https://geode.apache.org/) - An open source, distributed, in-memory database for scale-out applications. - [Gaffer](https://github.com/gchq/Gaffer) - A large-scale graph database. - Timeseries - [InfluxDB](https://github.com/influxdata/influxdb) - Scalable datastore for metrics, events, and real-time analytics. - [OpenTSDB](https://github.com/OpenTSDB/opentsdb) - A scalable, distributed Time Series Database. - [QuestDB](https://questdb.io/) - A relational column-oriented database designed for real-time analytics on time series and event data. - [kairosdb](https://github.com/kairosdb/kairosdb) - Fast scalable time series database. - [Heroic](https://github.com/spotify/heroic) - A scalable time series database based on Cassandra and Elasticsearch, by Spotify. - [Druid](https://github.com/apache/incubator-druid) - Column oriented distributed data store ideal for powering interactive applications. - [Riak-TS](https://basho.com/products/riak-ts/) - Riak TS is the only enterprise-grade NoSQL time series database optimized specifically for IoT and Time Series data. - [Akumuli](https://github.com/akumuli/Akumuli) - Akumuli is a numeric time-series database. It can be used to capture, store and process time-series data in real-time. The word "akumuli" can be translated from esperanto as "accumulate". - [Rhombus](https://github.com/Pardot/Rhombus) - A time-series object store for Cassandra that handles all the complexity of building wide row indexes. - [Dalmatiner DB](https://github.com/dalmatinerdb/dalmatinerdb) - Fast distributed metrics database. - [Blueflood](https://github.com/rackerlabs/blueflood) - A distributed system designed to ingest and process time series data. - [Timely](https://github.com/NationalSecurityAgency/timely) - Timely is a time series database application that provides secure access to time series data based on Accumulo and Grafana. - Other - [Tarantool](https://github.com/tarantool/tarantool/) - Tarantool is an in-memory database and application server. - [GreenPlum](https://github.com/greenplum-db/gpdb) - The Greenplum Database (GPDB) - An advanced, fully featured, open source data warehouse. It provides powerful and rapid analytics on petabyte scale data volumes. - [cayley](https://github.com/cayleygraph/cayley) - An open-source graph database. Google. - [Snappydata](https://github.com/SnappyDataInc/snappydata) - SnappyData: OLTP + OLAP Database built on Apache Spark. - [TimescaleDB](https://www.timescale.com/) - Built as an extension on top of PostgreSQL, TimescaleDB is a time-series SQL database providing fast analytics, scalability, with automated data management on a proven storage engine. ## Data Ingestion - [Kafka](https://kafka.apache.org/) - Publish-subscribe messaging rethought as a distributed commit log. - [BottledWater](https://github.com/confluentinc/bottledwater-pg) - Change data capture from PostgreSQL into Kafka. Deprecated. - [kafkat](https://github.com/airbnb/kafkat) - Simplified command-line administration for Kafka brokers. - [kafkacat](https://github.com/edenhill/kafkacat) - Generic command line non-JVM Apache Kafka producer and consumer. - [pg-kafka](https://github.com/xstevens/pg_kafka) - A PostgreSQL extension to produce messages to Apache Kafka. - [librdkafka](https://github.com/edenhill/librdkafka) - The Apache Kafka C/C++ library. - [kafka-docker](https://github.com/wurstmeister/kafka-docker) - Kafka in Docker. - [kafka-manager](https://github.com/yahoo/kafka-manager) - A tool for managing Apache Kafka. - [kafka-node](https://github.com/SOHU-Co/kafka-node) - Node.js client for Apache Kafka 0.8. - [Secor](https://github.com/pinterest/secor) - Pinterest's Kafka to S3 distributed consumer. - [Kafka-logger](https://github.com/uber/kafka-logger) - Kafka-winston logger for Node.js from uber. - [AWS Kinesis](https://aws.amazon.com/kinesis/) - A fully managed, cloud-based service for real-time data processing over large, distributed data streams. - [RabbitMQ](https://www.rabbitmq.com/) - Robust messaging for applications. - [FluentD](https://www.fluentd.org) - An open source data collector for unified logging layer. - [Embulk](https://www.embulk.org) - An open source bulk data loader that helps data transfer between various databases, storages, file formats, and cloud services. - [Apache Sqoop](https://sqoop.apache.org) - A tool designed for efficiently transferring bulk data between Apache Hadoop and structured datastores such as relational databases. - [Heka](https://github.com/mozilla-services/heka) - Data Acquisition and Processing Made Easy. Deprecated. - [Gobblin](https://github.com/apache/incubator-gobblin) - Universal data ingestion framework for Hadoop from Linkedin. - [Nakadi](https://nakadi.io) - Nakadi is an open source event messaging platform that provides a REST API on top of Kafka-like queues. - [Pravega](https://www.pravega.io) - Pravega provides a new storage abstraction - a stream - for continuous and unbounded data. - [Apache Pulsar](https://pulsar.apache.org/) - Apache Pulsar is an open-source distributed pub-sub messaging system. - [AWS Data Wranlger](https://github.com/awslabs/aws-data-wrangler) - Utility belt to handle data on AWS. - [Airbyte](https://airbyte.io/) - Open-source data integration for modern data teams. ## File System - [HDFS](https://hadoop.apache.org/docs/current/hadoop-project-dist/hadoop-hdfs/HdfsDesign.html) - A distributed file system designed to run on commodity hardware. - [Snakebite](https://github.com/spotify/snakebite) - A pure python HDFS client. - [AWS S3](https://aws.amazon.com/s3/) - Object storage built to retrieve any amount of data from anywhere. - [smart_open](https://github.com/RaRe-Technologies/smart_open) - Utils for streaming large files (S3, HDFS, gzip, bz2). - [Alluxio](https://www.alluxio.org/) - Alluxio is a memory-centric distributed storage system enabling reliable data sharing at memory-speed across cluster frameworks, such as Spark and MapReduce. - [CEPH](https://ceph.com/) - Ceph is a unified, distributed storage system designed for excellent performance, reliability and scalability. - [OrangeFS](https://www.orangefs.org/) - Orange File System is a branch of the Parallel Virtual File System. - [SnackFS](https://github.com/tuplejump/snackfs-release) - SnackFS is our bite-sized, lightweight HDFS compatible FileSystem built over Cassandra. - [GlusterFS](https://www.gluster.org/) - Gluster Filesystem. - [XtreemFS](https://www.xtreemfs.org/) - Fault-tolerant distributed file system for all storage needs. - [SeaweedFS](https://github.com/chrislusf/seaweedfs) - Seaweed-FS is a simple and highly scalable distributed file system. There are two objectives: to store billions of files! to serve the files fast! Instead of supporting full POSIX file system semantics, Seaweed-FS choose to implement only a key~file mapping. Similar to the word "NoSQL", you can call it as "NoFS". - [S3QL](https://github.com/s3ql/s3ql/) - S3QL is a file system that stores all its data online using storage services like Google Storage, Amazon S3, or OpenStack. - [LizardFS](https://lizardfs.com/) - LizardFS Software Defined Storage is a distributed, parallel, scalable, fault-tolerant, Geo-Redundant and highly available file system. ## Serialization format - [Apache Avro](https://avro.apache.org) - Apache Avro™ is a data serialization system. - [Apache Parquet](https://parquet.apache.org) - Apache Parquet is a columnar storage format available to any project in the Hadoop ecosystem, regardless of the choice of data processing framework, data model or programming language. - [Snappy](https://github.com/google/snappy) - A fast compressor/decompressor. Used with Parquet. - [PigZ](https://zlib.net/pigz/) - A parallel implementation of gzip for modern multi-processor, multi-core machines. - [Apache ORC](https://orc.apache.org/) - The smallest, fastest columnar storage for Hadoop workloads. - [Apache Thrift](https://thrift.apache.org) - The Apache Thrift software framework, for scalable cross-language services development. - [ProtoBuf](https://github.com/protocolbuffers/protobuf) - Protocol Buffers - Google's data interchange format. - [SequenceFile](https://wiki.apache.org/hadoop/SequenceFile) - SequenceFile is a flat file consisting of binary key/value pairs. It is extensively used in MapReduce as input/output formats. - [Kryo](https://github.com/EsotericSoftware/kryo) - Kryo is a fast and efficient object graph serialization framework for Java. ## Stream Processing - [Apache Beam](https://beam.apache.org/) - Apache Beam is a unified programming model that implements both batch and streaming data processing jobs that run on many execution engines. - [Spark Streaming](https://spark.apache.org/streaming/) - Spark Streaming makes it easy to build scalable fault-tolerant streaming applications. - [Apache Flink](https://flink.apache.org/) - Apache Flink is a streaming dataflow engine that provides data distribution, communication, and fault tolerance for distributed computations over data streams. - [Apache Storm](https://storm.apache.org) - Apache Storm is a free and open source distributed realtime computation system. - [Apache Samza](https://samza.apache.org) - Apache Samza is a distributed stream processing framework. - [Apache NiFi](https://nifi.apache.org/) - An easy to use, powerful, and reliable system to process and distribute data. - [Apache Hudi](https://hudi.apache.org/) - An open source framework for managing storage for real time processing, one of the most interesting feature is the Upsert. - [VoltDB](https://voltdb.com/) - VoltDb is an ACID-compliant RDBMS which uses a [shared nothing architecture](https://en.wikipedia.org/wiki/Shared-nothing_architecture). - [PipelineDB](https://github.com/pipelinedb/pipelinedb) - The Streaming SQL Database. - [Spring Cloud Dataflow](https://cloud.spring.io/spring-cloud-dataflow/) - Streaming and tasks execution between Spring Boot apps. - [Bonobo](https://www.bonobo-project.org/) - Bonobo is a data-processing toolkit for python 3.5+. - [Robinhood's Faust](https://github.com/faust-streaming/faust) - Forever scalable event processing & in-memory durable K/V store as a library with asyncio & static typing. - [HStreamDB](https://github.com/hstreamdb/hstream) - The streaming database built for IoT data storage and real-time processing. - [Kuiper](https://github.com/emqx/kuiper) - An edge lightweight IoT data analytics/streaming software implemented by Golang, and it can be run at all kinds of resource-constrained edge devices. - [Zilla](https://github.com/aklivity/zilla) - - An API gateway built for event-driven architectures and streaming that supports standard protocols such as HTTP, SSE, gRPC, MQTT and the native Kafka protocol. ## Batch Processing - [Hadoop MapReduce](https://hadoop.apache.org/docs/current/hadoop-mapreduce-client/hadoop-mapreduce-client-core/MapReduceTutorial.html) - Hadoop MapReduce is a software framework for easily writing applications which process vast amounts of data (multi-terabyte data-sets) - in-parallel on large clusters (thousands of nodes) - of commodity hardware in a reliable, fault-tolerant manner. - [Spark](https://spark.apache.org/) - A multi-language engine for executing data engineering, data science, and machine learning on single-node machines or clusters. - [Spark Packages](https://spark-packages.org) - A community index of packages for Apache Spark. - [Deep Spark](https://github.com/Stratio/deep-spark) - Connecting Apache Spark with different data stores. Deprecated. - [Spark RDD API Examples](https://homepage.cs.latrobe.edu.au/zhe/ZhenHeSparkRDDAPIExamples.html) - Examples by Zhen He. - [Livy](https://livy.incubator.apache.org) - The REST Spark Server. - [Delight](https://github.com/datamechanics/delight) - A free & cross platform monitoring tool (Spark UI / Spark History Server alternative). - [AWS EMR](https://aws.amazon.com/emr/) - A web service that makes it easy to quickly and cost-effectively process vast amounts of data. - [Data Mechanics](https://www.datamechanics.co) - A cloud-based platform deployed on Kubernetes making Apache Spark more developer-friendly and cost-effective. - [Tez](https://tez.apache.org/) - An application framework which allows for a complex directed-acyclic-graph of tasks for processing data. - [Bistro](https://github.com/asavinov/bistro) - A light-weight engine for general-purpose data processing including both batch and stream analytics. It is based on a novel unique data model, which represents data via _functions_ and processes data via _columns operations_ as opposed to having only set operations in conventional approaches like MapReduce or SQL. - Batch ML - [H2O](https://www.h2o.ai/) - Fast scalable machine learning API for smarter applications. - [Mahout](https://mahout.apache.org/) - An environment for quickly creating scalable performant machine learning applications. - [Spark MLlib](https://spark.apache.org/docs/latest/ml-guide.html) - Spark's scalable machine learning library consisting of common learning algorithms and utilities, including classification, regression, clustering, collaborative filtering, dimensionality reduction, as well as underlying optimization primitives. - Batch Graph - [GraphLab Create](https://turi.com/products/create/docs/) - A machine learning platform that enables data scientists and app developers to easily create intelligent apps at scale. - [Giraph](https://giraph.apache.org/) - An iterative graph processing system built for high scalability. - [Spark GraphX](https://spark.apache.org/graphx/) - Apache Spark's API for graphs and graph-parallel computation. - Batch SQL - [Presto](https://prestodb.github.io/docs/current/index.html) - A distributed SQL query engine designed to query large data sets distributed over one or more heterogeneous data sources. - [Hive](https://hive.apache.org) - Data warehouse software facilitates querying and managing large datasets residing in distributed storage. - [Hivemall](https://github.com/apache/incubator-hivemall) - Scalable machine learning library for Hive/Hadoop. - [PyHive](https://github.com/dropbox/PyHive) - Python interface to Hive and Presto. - [Drill](https://drill.apache.org/) - Schema-free SQL Query Engine for Hadoop, NoSQL and Cloud Storage. ## Charts and Dashboards - [Highcharts](https://www.highcharts.com/) - A charting library written in pure JavaScript, offering an easy way of adding interactive charts to your web site or web application. - [ZingChart](https://www.zingchart.com/) - Fast JavaScript charts for any data set. - [C3.js](https://c3js.org) - D3-based reusable chart library. - [D3.js](https://d3js.org/) - A JavaScript library for manipulating documents based on data. - [D3Plus](https://d3plus.org) - D3's simplier, easier to use cousin. Mostly predefined templates that you can just plug data in. - [SmoothieCharts](https://smoothiecharts.org) - A JavaScript Charting Library for Streaming Data. - [PyXley](https://github.com/stitchfix/pyxley) - Python helpers for building dashboards using Flask and React. - [Plotly](https://github.com/plotly/dash) - Flask, JS, and CSS boilerplate for interactive, web-based visualization apps in Python. - [Apache Superset](https://github.com/apache/incubator-superset) - Apache Superset (incubating) - A modern, enterprise-ready business intelligence web application. - [Redash](https://redash.io/) - Make Your Company Data Driven. Connect to any data source, easily visualize and share your data. - [Metabase](https://github.com/metabase/metabase) - Metabase is the easy, open source way for everyone in your company to ask questions and learn from data. - [PyQtGraph](https://www.pyqtgraph.org/) - PyQtGraph is a pure-python graphics and GUI library built on PyQt4 / PySide and numpy. It is intended for use in mathematics / scientific / engineering applications. ## Workflow - [Luigi](https://github.com/spotify/luigi) - Luigi is a Python module that helps you build complex pipelines of batch jobs. - [CronQ](https://github.com/seatgeek/cronq) - An application cron-like system. [Used](https://chairnerd.seatgeek.com/building-out-the-seatgeek-data-pipeline/) w/Luige. Deprecated. - [Cascading](https://www.cascading.org/) - Java based application development platform. - [Airflow](https://github.com/apache/airflow) - Airflow is a system to programmaticaly author, schedule and monitor data pipelines. - [Azkaban](https://azkaban.github.io/) - Azkaban is a batch workflow job scheduler created at LinkedIn to run Hadoop jobs. Azkaban resolves the ordering through job dependencies and provides an easy to use web user interface to maintain and track your workflows. - [Oozie](https://oozie.apache.org/) - Oozie is a workflow scheduler system to manage Apache Hadoop jobs. - [Pinball](https://github.com/pinterest/pinball) - DAG based workflow manager. Job flows are defined programmaticaly in Python. Support output passing between jobs. - [Dagster](https://github.com/dagster-io/dagster) - Dagster is an open-source Python library for building data applications. - [Kedro](https://kedro.readthedocs.io/en/latest/) - Kedro is a framework that makes it easy to build robust and scalable data pipelines by providing uniform project templates, data abstraction, configuration and pipeline assembly. - [Dataform](https://dataform.co/) - An open-source framework and web based IDE to manage datasets and their dependencies. SQLX extends your existing SQL warehouse dialect to add features that support dependency management, testing, documentation and more. - [Census](https://getcensus.com/) - A reverse-ETL tool that let you sync data from your cloud data warehouse to SaaS applications like Salesforce, Marketo, HubSpot, Zendesk, etc. No engineering favors required—just SQL. - [dbt](https://getdbt.com/) - A command line tool that enables data analysts and engineers to transform data in their warehouses more effectively. - [RudderStack](https://github.com/rudderlabs/rudder-server) - A warehouse-first Customer Data Platform that enables you to collect data from every application, website and SaaS platform, and then activate it in your warehouse and business tools. ## Data Lake Management - [lakeFS](https://github.com/treeverse/lakeFS) - lakeFS is an open source platform that delivers resilience and manageability to object-storage based data lakes. ## ELK Elastic Logstash Kibana - [docker-logstash](https://github.com/pblittle/docker-logstash) - A highly configurable logstash (1.4.4) - docker image running Elasticsearch (1.7.0) - and Kibana (3.1.2). - [elasticsearch-jdbc](https://github.com/jprante/elasticsearch-jdbc) - JDBC importer for Elasticsearch. - [ZomboDB](https://github.com/zombodb/zombodb) - Postgres Extension that allows creating an index backed by Elasticsearch. ## Docker - [Gockerize](https://github.com/redbooth/gockerize) - Package golang service into minimal docker containers. - [Flocker](https://github.com/ClusterHQ/flocker) - Easily manage Docker containers & their data. - [Rancher](https://rancher.com/rancher-os/) - RancherOS is a 20mb Linux distro that runs the entire OS as Docker containers. - [Kontena](https://www.kontena.io/) - Application Containers for Masses. - [Weave](https://github.com/weaveworks/weave) - Weaving Docker containers into applications. - [Zodiac](https://github.com/CenturyLinkLabs/zodiac) - A lightweight tool for easy deployment and rollback of dockerized applications. - [cAdvisor](https://github.com/google/cadvisor) - Analyzes resource usage and performance characteristics of running containers. - [Micro S3 persistence](https://github.com/figadore/micro-s3-persistence) - Docker microservice for saving/restoring volume data to S3. - [Rocker-compose](https://github.com/grammarly/rocker-compose) - Docker composition tool with idempotency features for deploying apps composed of multiple containers. Deprecated. - [Nomad](https://github.com/hashicorp/nomad) - Nomad is a cluster manager, designed for both long lived services and short lived batch processing workloads. - [ImageLayers](https://imagelayers.io/) - Vizualize docker images and the layers that compose them. ## Datasets ### Realtime - [Twitter Realtime](https://developer.twitter.com/en/docs/tweets/filter-realtime/overview) - The Streaming APIs give developers low latency access to Twitter's global stream of Tweet data. - [Eventsim](https://github.com/Interana/eventsim) - Event data simulator. Generates a stream of pseudo-random events from a set of users, designed to simulate web traffic. - [Reddit](https://www.reddit.com/r/datasets/comments/3mk1vg/realtime_data_is_available_including_comments/) - Real-time data is available including comments, submissions and links posted to reddit. ### Data Dumps - [GitHub Archive](https://www.gharchive.org/) - GitHub's public timeline since 2011, updated every hour. - [Common Crawl](https://commoncrawl.org/) - Open source repository of web crawl data. - [Wikipedia](https://dumps.wikimedia.org/enwiki/latest/) - Wikipedia's complete copy of all wikis, in the form of wikitext source and metadata embedded in XML. A number of raw database tables in SQL form are also available. ## Monitoring ### Prometheus - [Prometheus.io](https://github.com/prometheus/prometheus) - An open-source service monitoring system and time series database. - [HAProxy Exporter](https://github.com/prometheus/haproxy_exporter) - Simple server that scrapes HAProxy stats and exports them via HTTP for Prometheus consumption. ## Testing - [Grai](https://github.com/grai-io/grai-core/) - A data catalog tool that integrates into your CI system exposing downstream impact testing of data changes. These tests prevent data changes which might break data pipelines or BI dashboards from making it to production. ## Community ### Forums - [/r/dataengineering](https://www.reddit.com/r/dataengineering/) - News, tips and background on Data Engineering. - [/r/etl](https://www.reddit.com/r/ETL/) - Subreddit focused on ETL. ### Conferences - [Data Council](https://www.datacouncil.ai/about) - Data Council is the first technical conference that bridges the gap between data scientists, data engineers and data analysts. ### Podcasts - [Data Engineering Podcast](https://www.dataengineeringpodcast.com/) - The show about modern data infrastructure.
96.40411
388
0.766288
awesome-data-engineering
https://github.com/igorbarinov/awesome-data-engineering
A curated list of data engineering tools for software developers
5,457
1,029
2023-12-04 22:33:30+00:00
2015-06-18 19:39:42+00:00
226
Creative Commons Zero v1.0 Universal
Misc
# Contribution Guidelines Please ensure your pull request adheres to the following guidelines: - Search previous suggestions before making a new one, as yours may be a duplicate. - Make sure your list is useful before submitting. That implies it having enough content and every item a good succinct description. - Link name or description should only include alphanumeric text, no emojis or images. - A link back to this list from yours, so users can discover more lists, would be appreciated. - Make an individual pull request for each suggestion. - Titles should be [capitalized](http://grammar.yourdictionary.com/capitalization/rules-for-capitalization-in-titles.html). - Use the following format: `[List Name](link)` - Link additions should be added to the bottom of the relevant category. - New categories or improvements to the existing categorization are welcome. - Check your spelling and grammar. - Make sure your text editor is set to remove trailing whitespace. - The pull request and commit should have a useful title. Thank you for your suggestions!
52.4
132
0.794752
awesome-data-engineering
https://github.com/igorbarinov/awesome-data-engineering
A curated list of data engineering tools for software developers
5,457
1,029
2023-12-04 22:33:30+00:00
2015-06-18 19:39:42+00:00
226
Creative Commons Zero v1.0 Universal
Misc
CC0 1.0 Universal Statement of Purpose The laws of most jurisdictions throughout the world automatically confer exclusive Copyright and Related Rights (defined below) upon the creator and subsequent owner(s) (each and all, an "owner") of an original work of authorship and/or a database (each, a "Work"). Certain owners wish to permanently relinquish those rights to a Work for the purpose of contributing to a commons of creative, cultural and scientific works ("Commons") that the public can reliably and without fear of later claims of infringement build upon, modify, incorporate in other works, reuse and redistribute as freely as possible in any form whatsoever and for any purposes, including without limitation commercial purposes. These owners may contribute to the Commons to promote the ideal of a free culture and the further production of creative, cultural and scientific works, or to gain reputation or greater distribution for their Work in part through the use and efforts of others. For these and/or other purposes and motivations, and without any expectation of additional consideration or compensation, the person associating CC0 with a Work (the "Affirmer"), to the extent that he or she is an owner of Copyright and Related Rights in the Work, voluntarily elects to apply CC0 to the Work and publicly distribute the Work under its terms, with knowledge of his or her Copyright and Related Rights in the Work and the meaning and intended legal effect of CC0 on those rights. Copyright and Related Rights. A Work made available under CC0 may be protected by copyright and related or neighboring rights ("Copyright and Related Rights"). Copyright and Related Rights include, but are not limited to, the following: i. the right to reproduce, adapt, distribute, perform, display, communicate, and translate a Work; ii. moral rights retained by the original author(s) and/or performer(s); iii. publicity and privacy rights pertaining to a person's image or likeness depicted in a Work; iv. rights protecting against unfair competition in regards to a Work, subject to the limitations in paragraph 4(a), below; v. rights protecting the extraction, dissemination, use and reuse of data in a Work; vi. database rights (such as those arising under Directive 96/9/EC of the European Parliament and of the Council of 11 March 1996 on the legal protection of databases, and under any national implementation thereof, including any amended or successor version of such directive); and vii. other similar, equivalent or corresponding rights throughout the world based on applicable law or treaty, and any national implementations thereof. Waiver. To the greatest extent permitted by, but not in contravention of, applicable law, Affirmer hereby overtly, fully, permanently, irrevocably and unconditionally waives, abandons, and surrenders all of Affirmer's Copyright and Related Rights and associated claims and causes of action, whether now known or unknown (including existing as well as future claims and causes of action), in the Work (i) in all territories worldwide, (ii) for the maximum duration provided by applicable law or treaty (including future time extensions), (iii) in any current or future medium and for any number of copies, and (iv) for any purpose whatsoever, including without limitation commercial, advertising or promotional purposes (the "Waiver"). Affirmer makes the Waiver for the benefit of each member of the public at large and to the detriment of Affirmer's heirs and successors, fully intending that such Waiver shall not be subject to revocation, rescission, cancellation, termination, or any other legal or equitable action to disrupt the quiet enjoyment of the Work by the public as contemplated by Affirmer's express Statement of Purpose. Public License Fallback. Should any part of the Waiver for any reason be judged legally invalid or ineffective under applicable law, then the Waiver shall be preserved to the maximum extent permitted taking into account Affirmer's express Statement of Purpose. In addition, to the extent the Waiver is so judged Affirmer hereby grants to each affected person a royalty-free, non transferable, non sublicensable, non exclusive, irrevocable and unconditional license to exercise Affirmer's Copyright and Related Rights in the Work (i) in all territories worldwide, (ii) for the maximum duration provided by applicable law or treaty (including future time extensions), (iii) in any current or future medium and for any number of copies, and (iv) for any purpose whatsoever, including without limitation commercial, advertising or promotional purposes (the "License"). The License shall be deemed effective as of the date CC0 was applied by Affirmer to the Work. Should any part of the License for any reason be judged legally invalid or ineffective under applicable law, such partial invalidity or ineffectiveness shall not invalidate the remainder of the License, and in such case Affirmer hereby affirms that he or she will not (i) exercise any of his or her remaining Copyright and Related Rights in the Work or (ii) assert any associated claims and causes of action with respect to the Work, in either case contrary to Affirmer's express Statement of Purpose. Limitations and Disclaimers. a. No trademark or patent rights held by Affirmer are waived, abandoned, surrendered, licensed or otherwise affected by this document. b. Affirmer offers the Work as-is and makes no representations or warranties of any kind concerning the Work, express, implied, statutory or otherwise, including without limitation warranties of title, merchantability, fitness for a particular purpose, non infringement, or the absence of latent or other defects, accuracy, or the present or absence of errors, whether or not discoverable, all to the greatest extent permissible under applicable law. c. Affirmer disclaims responsibility for clearing rights of other persons that may apply to the Work or any use thereof, including without limitation any person's Copyright and Related Rights in the Work. Further, Affirmer disclaims responsibility for obtaining any necessary consents, permissions or other rights required for any use of the Work. d. Affirmer understands and acknowledges that Creative Commons is not a party to this document and has no duty or obligation with respect to this CC0 or use of the Work. For more information, please see https://creativecommons.org/publicdomain/zero/1.0
157.02439
1,460
0.810898
Data-Engineering-HowTo
https://github.com/adilkhash/Data-Engineering-HowTo
A list of useful resources to learn Data Engineering from scratch
2,916
420
2023-12-04 22:40:42+00:00
2019-03-28 07:43:26+00:00
39
null
Misc
# How To Become a Data Engineer ### Useful articles - [The AI Hierarchy of Needs](https://hackernoon.com/the-ai-hierarchy-of-needs-18f111fcc007) - [The Rise of Data Engineer](https://medium.freecodecamp.org/the-rise-of-the-data-engineer-91be18f1e603) - [The Downfall of the Data Engineer](https://medium.com/@maximebeauchemin/the-downfall-of-the-data-engineer-5bfb701e5d6b) - A Beginner’s Guide to Data Engineering - [Part I](https://medium.com/@rchang/a-beginners-guide-to-data-engineering-part-i-4227c5c457d7) - [Part II](https://medium.com/@rchang/a-beginners-guide-to-data-engineering-part-ii-47c4e7cbda71?source=---------5------------------) - [Part III](https://medium.com/@rchang/a-beginners-guide-to-data-engineering-the-series-finale-2cc92ff14b0?source=---------4------------------) - [Functional Data Engineering — a modern paradigm for batch data processing](https://medium.com/@maximebeauchemin/functional-data-engineering-a-modern-paradigm-for-batch-data-processing-2327ec32c42a) - How to become a Data Engineer [Ru](https://khashtamov.com/ru/data-engineer/), [En](https://khashtamov.com/en/how-to-become-a-data-engineer/) - Introduction to Apache Airflow [Ru](https://khashtamov.com/ru/apache-airflow-introduction/?utm_source=github&utm_medium=dataeng-repository&utm_campaign=dataeng), [En](https://khashtamov.com/en/introduction-to-apache-airflow/) ### Talks - [Data Engineering Principles - Build frameworks not pipelines](https://www.youtube.com/watch?v=pzfgbSfzhXg) by Gatis Seja - [Functional Data Engineering - A Set of Best Practices](https://www.youtube.com/watch?v=4Spo2QRTz1k) by Maxime Beauchemin - [Advanced Data Engineering Patterns with Apache Airflow](https://www.youtube.com/watch?v=Fvu2oFyFCT0) by Maxime Beauchemin - [Creating a Data Engineering Culture](https://www.youtube.com/watch?v=VkeleGIUSM8) by Jesse Anderson - [Streaming 101: Hello Streaming](https://www.youtube.com/watch?v=A1YC_AC0qf8) by Josh Fischer ### Algorithms & Data Structures - [Algorithmic Toolbox](https://stepik.org/course/217) in Russian - [Data Structures](https://stepik.org/course/1547) in Russian - [Data Structures & Algorithms Specialization](https://www.coursera.org/specializations/data-structures-algorithms) on Coursera - [Algorithms Specialization](https://www.coursera.org/specializations/algorithms) from Stanford on Coursera ### SQL - [Comprehensive SQL Tutorial](https://mode.com/sql-tutorial/introduction-to-sql/) by Mode Analytics - [SQL Practice](https://leetcode.com/problemset/database/) on Leetcode - [Modern SQL](https://modern-sql.com/) a website about modern SQL syntax - Introduction to Window Functions [En](https://khashtamov.com/en/sql-window-functions/), [Ru](https://khashtamov.com/ru/window-functions-sql/) ### Programming - [Scala School](https://twitter.github.io/scala_school/) by Twitter - [Fluent Python](https://www.amazon.com/gp/product/1491946008/ref=as_li_tl?ie=UTF8&camp=1789&creative=9325&creativeASIN=1491946008&linkCode=as2&tag=adilkhash-20&linkId=8a663e966770c24874e323133cc7a005) intermediate level book about Python - [Intro to Scala](https://stepik.org/course/16243) in Russian on Stepik by Tinkoff Bank - [The Hitchhiker’s Guide to Python](https://docs.python-guide.org/) by Kenneth Reitz & Tanya Schlusser - [Learn Python 3 The Hard Way](https://learnpythonthehardway.org/python3/) by Zed A. Shaw ### Databases - [Intro to Database Systems](https://www.youtube.com/playlist?list=PLSE8ODhjZXjYutVzTeAds8xUt1rcmyT7x) by Carnegie Mellon University - [Advanced Database Systems](https://www.youtube.com/playlist?list=PLSE8ODhjZXja7K1hjZ01UTVDnGQdx5v5U) by Carnegie Mellon University - On Disk IO - I. [Flavors of IO](https://medium.com/databasss/on-disk-io-part-1-flavours-of-io-8e1ace1de017) - II. [More Flavours of IO](https://medium.com/databasss/on-disk-io-part-2-more-flavours-of-io-c945db3edb13) - III. [LSM Trees](https://medium.com/databasss/on-disk-io-part-3-lsm-trees-8b2da218496f) - IV. [B-Trees and RUM Conjecture](https://medium.com/databasss/on-disk-storage-part-4-b-trees-30791060741) - V. [Access Patterns in LSM Trees](https://medium.com/databasss/on-disk-io-access-patterns-in-lsm-trees-2ba8dffc05f9) ### Distributed Systems - [Distributed systems for fun and profit](http://book.mixu.net/distsys/) by Mikito Takada - [Distributed Systems](https://www.amazon.com/gp/product/1543057381/ref=as_li_tl?ie=UTF8&camp=1789&creative=9325&creativeASIN=1543057381&linkCode=as2&tag=adilkhash-20&linkId=721aedeb23c313bc46a92c134c5baafa) by Maarten van Steen & Andrew S. Tanenbaum - [CSE138: Distributed Systems](https://www.youtube.com/playlist?list=PLNPUF5QyWU8O0Wd8QDh9KaM1ggsxspJ31) by Lindsey Kuper - [CS 436: Distributed Computer Systems](https://www.youtube.com/watch?v=w8KFPWkK0bI&list=PLawkBQ15NDEkDJ5IyLIJUTZ1rRM9YQq6N&index=2) by University of Waterloo - [MIT 6.824: Distributed Systems](https://www.youtube.com/playlist?list=PLrw6a1wE39_tb2fErI4-WkMbsvGQk9_UB) by Robert Morris from MIT - [Distributed consensus reading list](https://github.com/heidi-ann/distributed-consensus-reading-list) maintained by Heidi Howard from University of Cambridge ### Books - [Design Data-Intensive Applications](https://www.amazon.com/gp/product/1449373321/ref=as_li_tl?ie=UTF8&camp=1789&creative=9325&creativeASIN=1449373321&linkCode=as2&tag=adilkhash-20&linkId=e7e0e096aa5761066245eb90965ac849) by Martin Kleppmann - [Introduction to Algorithms](https://www.amazon.com/gp/product/0262033844/ref=as_li_tl?ie=UTF8&camp=1789&creative=9325&creativeASIN=0262033844&linkCode=as2&tag=adilkhash-20&linkId=74742875db503b1a899ca35159749067) by Thomas Cormen - [The Data Warehouse Toolkit: The Definitive Guide to Dimensional Modeling](https://www.amazon.com/gp/product/1118530802/ref=as_li_tl?ie=UTF8&tag=adilkhash-20&camp=1789&creative=9325&linkCode=as2&creativeASIN=1118530802&linkId=6ca865e8e9817dca57718bdbe5e52cd5) - [Star Schema The Complete Reference](https://www.amazon.com/gp/product/0071744320/ref=as_li_tl?ie=UTF8&tag=adilkhash-20&camp=1789&creative=9325&linkCode=as2&creativeASIN=0071744320&linkId=2abf9ef1d327071f74f59c3659ed6223) - [Database Internals: A Deep Dive into How Distributed Data Systems Work](https://www.amazon.com/gp/product/1492040347/ref=as_li_tl?ie=UTF8&camp=1789&creative=9325&creativeASIN=1492040347&linkCode=as2&tag=adilkhash-20&linkId=4a23dead1aeb11fd4debffb36487aa14) - [Streaming Systems: The What, Where, When, and How of Large-Scale Data Processing](https://www.amazon.com/gp/product/1491983876/ref=as_li_tl?ie=UTF8&camp=1789&creative=9325&creativeASIN=1491983876&linkCode=as2&tag=adilkhash-20&linkId=9869047f1ac02b597d8a0e67fd29ad68) - [A Philosophy of Software Design](https://www.amazon.com/gp/product/1732102201/ref=as_li_tl?ie=UTF8&camp=1789&creative=9325&creativeASIN=1732102201&linkCode=as2&tag=adilkhash-20&linkId=b020fab52fa5f1fed2191ea12e824468) - [Grokking Streaming Systems](https://www.manning.com/books/grokking-streaming-systems) by Josh Fischer & Ning Wang - [Guide to High Performance Distributed Computing](https://www.amazon.com/Guide-High-Performance-Distributed-Computing/dp/3319134965) by K.G. Srinivasa & Anil Kumar Muppalla - [Data Pipelines with Apache Airflow](https://www.manning.com/books/data-pipelines-with-apache-airflow) by Bas P. Harenslak and Julian Rutger de Ruiter ### Courses - [Data Engineering on Google Cloud Platform Specialization](https://www.coursera.org/specializations/gcp-data-machine-learning) by Google - [Data Engineer Nanodegree](https://udacity.com/course/data-engineer-nanodegree--nd027) by Udacity - [Data Engineering with Python](https://www.datacamp.com/tracks/data-engineer-with-python) by DataCamp ### Blogs - [Martin Kleppmann](https://martin.kleppmann.com/) author of Designing Data-Intensive Application - [BaseDS](https://medium.com/baseds) by Vaidehi Joshi about Distributed Systems ### Tools - [Apache Airflow](https://airflow.apache.org/) is a platform to programmatically author, schedule and monitor workflows in Python - [Apache Spark](https://spark.apache.org/) is a unified analytics engine for large-scale data processing - [Apache Kafka](https://kafka.apache.org/) is a distributed streaming platform - [Luigi](https://luigi.readthedocs.io) is a Python package that helps you build complex pipelines of batch jobs. - [Dagster.io](https://docs.dagster.io) is a system for building modern data applications. - [Prefect](https://prefect.io) includes everything you need to create and run data applications. - [Metaflow](https://github.com/Netflix/metaflow) build and manage real-life data science projects with ease - [lakeFS](https://github.com/treeverse/lakeFS) build repeatable, atomic and versioned data lake operations – from complex ETL jobs to data science and analytics. ### Cloud Platforms - [Amazon Web Services](https://aws.amazon.com/) - [Google Cloud Platform](https://cloud.google.com/gcp/) - [Microsoft Azure](https://azure.microsoft.com) - [Yandex Cloud](https://cloud.yandex.ru/) - [DigitalOcean](https://m.do.co/c/e92056c9e79b) - [IBM Cloud](https://www.ibm.com/cloud/) ### Communities - [data Engineering](https://t.me/dataeng_chat) - telegram chat about data engineering - [Data Engineering Subreddit](https://www.reddit.com/r/dataengineering/) - subreddit about data engineering ### Data Engineering Jobs - [Data Engineering jobs](http://bit.ly/2vk0R86) ### Other - [Data Engineering Podcast](https://www.dataengineeringpodcast.com/) ### Newsletters & Digests - [DataEng Telegram channel](https://t.me/dataeng) - Telegram channel about data engineering (rus/eng) - [Data Engineering Weekly](https://www.dataengineeringweekly.com/) - [SF Data Weekly](http://weekly.sfdata.io) - A weekly email of useful links for people interested in building data platforms - [Data Elixir](https://dataelixir.com/) - Data Elixir is an email newsletter that keeps you on top of the tools and trends in Data Science. - [Data Governance, Privacy and Security](https://dbadmin.news/) - DbAdmin News is a news letter on the technology behind Data Governance, Security and Privacy
86.565217
269
0.779919
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
# Data Engineering Projects ![](https://github.com/san089/Udacity-Data-Engineering-Projects/blob/master/image.jpeg) ## Project 1: Data Modeling with Postgres In this project, we apply Data Modeling with Postgres and build an ETL pipeline using Python. A startup wants to analyze the data they've been collecting on songs and user activity on their new music streaming app. Currently, they are collecting data in json format and the analytics team is particularly interested in understanding what songs users are listening to. Link: [Data_Modeling_with_Postgres](https://github.com/san089/Udacity-Data-Engineering-Projects/tree/master/Data_Modeling_with_Postgres) ## Project 2: Data Modeling with Cassandra In this project, we apply Data Modeling with Cassandra and build an ETL pipeline using Python. We will build a Data Model around our queries that we want to get answers for. For our use case we want below answers: - Get details of a song that was herad on the music app history during a particular session. - Get songs played by a user during particular session on music app. - Get all users from the music app history who listened to a particular song. Link : [Data_Modeling_with_Apache_Cassandra](https://github.com/san089/Udacity-Data-Engineering-Projects/tree/master/Data_Modeling_with_Apache_Cassandra) ## Project 3: Data Warehouse In this project, we apply the Data Warehouse architectures we learnt and build a Data Warehouse on AWS cloud. We build an ETL pipeline to extract and transform data stored in json format in s3 buckets and move the data to Warehouse hosted on Amazon Redshift. Use Redshift IaC script - [Redshift_IaC_README](https://github.com/san089/Udacity-Data-Engineering-Projects/blob/master/Redshift_IaC_README.md) Link - [Data_Warehouse](https://github.com/san089/Udacity-Data-Engineering-Projects/tree/master/Data_Warehouse) ## Project 4: Data Lake In this project, we will build a Data Lake on AWS cloud using Spark and AWS EMR cluster. The data lake will serve as a Single Source of Truth for the Analytics Platform. We will write spark jobs to perform ELT operations that picks data from landing zone on S3 and transform and stores data on the S3 processed zone. Link: [Data_Lake](https://github.com/san089/Udacity-Data-Engineering-Projects/tree/master/Data_Lake) ## Project 5: Data Pipelines with Airflow In this project, we will orchestrate our Data Pipeline workflow using an open-source Apache project called Apache Airflow. We will schedule our ETL jobs in Airflow, create project related custom plugins and operators and automate the pipeline execution. Link: [Airflow_Data_Pipelines](https://github.com/san089/Udacity-Data-Engineering-Projects/tree/master/Airflow_Data_Pipelines) ## Project 6: Api Data to Postgres In this project, we build an etl pipeline to fetch data from yelp API and insert it into the Postgres Database. This project is a very basic example of fetching real time data from an open source API. Link: [API to Postgres](https://github.com/san089/Udacity-Data-Engineering-Projects/tree/master/Data_Api_to_Postgres) ## CAPSTONE PROJECT Udacity provides their own crafted Capstone project with dataset that include data on immigration to the United States, and supplementary datasets that include data on airport codes, U.S. city demographics, and temperature data. I worked on my own open-ended project. <br /> Here is the link - [goodreads_etl_pipeline](https://github.com/san089/goodreads_etl_pipeline)
73.425532
367
0.794109
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
�PNG  IHDR�5��S�PLTEFFFIIIrqqUTT���MON�RC�VH�2$�RC��КRF[[Z���eee3Ȍ���������```lkk���������������xww}}}���������������������������;�pAmZtttnE;6���L:߮Cǀ7�?0̾�` �����{�.���IDATx��[�>�sV�L���mnӯ.g ����sO���AqZ�熋��-���=MbUS@��)�Z *�b *�b *�b *�b *�b *�b *�b *�bԴ�����h�l'�S�.���R��q ��'�*@�@�Mh�V`|@T @�@T @�T.��'�R�~L~+:�E�Ue@�afR�QD�`ź� V"ea=@\���X)�I5�Ef�X�EU�ePf����) �"�]�+'�Ƙ��R۩f��������͢��dDYd1@�:Q����}MJ��S w�1�m]�ԓ�Af��*BL�_&��KS�q�f�.�X���(�{,�pܥ�kT�f`ˠ�l�7�bI� 񬫊�������p�pٻ_c]�&��nɯ��Y��LE@j#�c'Y����R@�2b)HE��M�3���R�g@T�M8ӓ}v/��4q�\��Q גWDq%R�� ���5��T.���B�(D���������9i%321��� @L��z ��ȅ� �_��W&��Tu`*����W�=�:�[x^1v�ۣ�8+ �h�/B3��KF�W�� @Q?(�<�똅J\/��e�� 0s��[[iR��U5�B�2�o2_$��N#���k��uo��]�^@ܩ���-FKu�@qzѤ��� �s�B�* 9���6�7� �̈�A�����;$��l�p�e�v�J2F�NZ�:4@q�7�^��,�{#�KНM�C����g����{�rĥ@��NB6�[f#4@\[t��3@��2 ���3�����e��*�X׭"2���*��, ��>�����)����fk�Ϫ�wȤ~"]�=@9�d�B�"�FtX0�\'Ԗ����^�͚�=�#�0��J%�&m� C��`�k< Ģ��n�P���t��P*!�;t�� ��q��گ�5��G���������P������Q��M�i��٣�)�� g�^Tg��+�b�(��1�>z���<Y����/�<�"i���l*`�xd&� &��?��9�^�T�7f�q�(��5@6g���g��� @SږSm0��"�Y����z�<b1�}X�3g@�E�� 3%M�~=�e� �}�;��t���“|��,�� �M m� ��ۺ y��X�8�����JH�^�00��s�>�r��a�,�L��P��� �Ҧy&>$g�:��?:G�������⬼��{!�t�1r�\ix��q���a*z����Em��iɈ{�40#�@r��p �$T�X���Gf2�"f*�3��ð��H��H>�D��λ�8=������n <��<�� 3El�տ�(6��ieq�������poSu~��I�fʫ�帛���6;clhۖT�� �"����_�Ƚ*���]�L`'�7���s���%����Z��jn ~�����1 �6����������6��ձ 88 �q2���2�c(����8�������#@h�9�P���3(��@n�9�P���e�������@n�ePf��ׁ� ����@��C��D����� `u�(S`�������&����'����2�='�&��Y�2�='�g�@P/��� ��`��N�2`������ �0����� �0���I�ρ�w�Xp� �Qk9u�O���{k˙ �njNc��k���ju��~�HX��������V@y?���OC�ύ�!᧳hq����N� hh� k�o��ſ@��&�Do����ZzE������X� �����gyFj�����T}�2S�l���N�VL�p�mݎ��&��کm�/cڪ!ד��_��3��PY��b~��yx�z �<ŝܚYd/�^_��|�,z%�{P6���qP���vu�r�T`����d>�|k�)�����������]�'���,���N�?t}���D�_ ����o$��n}�gd�G���B[��i��6���zy=St�\v��?\/��.)���r��������/s[|=�s���������������iq|��R�7W���_��������=H�)��4��?mz�$�[�����v@{�r�W��Q�����_�?'�/�����9�nm�p���+��|�_sw�p 9�C4?�ub�:??S��]��LL��=�2rپ�O+���T�DMc�MÔ>���~a:�_]�mfd ��gԶ�n�����p��.�s�Bw���m�{�!Z�mCwM� `i떤~w�s���EWyr��2p�D������������;��Q. ��/�2 �&���E�z�w�pZ��vӤ3���wF�����hx��(�R�g6uC� ? �m٥}�Y����2�} `��O�B����Llik ������}Z0�u]����0����<�f���`���������1�k�ٜ:����W����e�-C~��?~h����xo�ח�9 @vZ[�ʕ-��Y<�J�JsU�Q�Y�s�K#:�s�w��L�C�@LιV��l�"��H�V�U"&�s!JL����XQw�ox=pٞ������"��兣�a��S�Dᡧ�@���o�R�`�K���[߮t�;V�q'j�K�T�ʛ���x�Ё��T�IԘ�����ΚA�҄�����bID@���q&%`���� o�u�8l>�P�����"�b Fp�G�)�NʤCTO��;�����0IoВk���<3F�����&H�S����P�˶� JW@;� �O�B|���c:H�r�J[u<c�¤d� �0�ڬ߾- �yD_�6����/t��s3R�>�8�6G�aO�,�@Sߒ#4�?@J&`#��eY�����F0JA�e\��󚖹�(�1��s�UoYU*�ƚD�2^�����nf,�l���uZ�>l1�����p�@-�����+˃' ��Y�}x�P@PD��G�-��^��}�!���a����<��i *8��&Ea&�0c�l�����+0@�mӪ\�r�������nvL����[����0�p)����� ���a������� ���3���Y��m,j;���NrDc ��8wDbD�����u��Z� �-~���06�d�mG'E���UkE�r� �u ��Vޢ0�NDQr��J�4ŘI̮_���9���z�/u�_:<�)ڟ�� ��z?�Q�`��p��J��>�dM�����~ޯ��t�� �r]j��{ �j�.L�s � ��zT�a��S?)�Y 9�� o�)y�+� 3��j��"����Q�����Ë�����ڼ���֗k��6����i|�h�3�'�t�˦Vπ�!���[NӖ�Q��e߈c�h�g d���=cE[�m���)ز.��M�$��ԏ7������e�t)%�գ I�nX�X�x�5C����6wGM�}� ���p� ��͉�`�Q�!!^z�%�s0�] �s[B��y�!�sM���s�7��PJ�+J�s[�$��QO��O=��=?u|4��_ȣ�*#j�Ә����:��S\^��j���y��X��뵰i�-cb�7�V�����Xs�u��_�x��.�.q� fM<�Z���%����bͨu�'-��J�8�,.�|X|C�xV��?-"���fo���Ǐ3`I���V���m?��֧�@��<6��_�Wo r+�~3���0�i�}�K{���� V��_��E�WBc�F�l!g_�L��aQ>�����8���4g��B5�X�J7|$ɺ�m ���,��@ӌ�y��^˧;��U��wD̖A��/����P�X ����ca`��w�'p*���~7H���/%Ю�/n �ѥ Ϋ��V�KR� ^�x��;2eK�ʯ��:��o�e}���+�l�`�����,P)>�'_=D?Pof�L�xz�CN�N���~�6垉��*� W� Bu �FP���Va<�t8}�ۺ{X���|ᵇS�: �%| �U��/>�� s��{r'���e��_^5�E���E�k�)�J�E�\E�y?P�`�wَM� 3��@�L�0Td�� 0�s�$0db;�!$� �y�V �E ~:؇�D�J;�u���.KBL��z/> (�G ��i�&����ULfm<�&����� F��N�f!`�7n���nB������v�LGo�Mk>_x�(J��p^�j`�.�疡���sQn�f6@i_�,��f:�������� %YN�8��Ү� �j<\���K�L� ^ >���|!��LKι���+a����I��*Lۈ�CG�����qf� �5��Sَ� P�kfP�K�ʠϺ:�����EN�E��k�2,��2*C���ZkRc��@�g�FgU�+���#��<��4��5J�L��]r�f�3L��l1S���Q0�D�E���k���ۀ:��-�"E$x�o!9C)8�S�p��G��{���V�_�!a[Q��{�r��3g([��˨8&� (F8 Kv��KQ�6,�|v�W6��ǩ�zX�ˡ4�(��n��6H=���P�����終~-`"\�Z����*��a��Q����jP�!�k �yXڵ��`Z��خ�*e������(�ZL8�n�J0T�Ny��p�m�Em�L���Y �C�����!:�u��I�(!����w�� ���b&�C�Xs����q_4���q �2V�� r!�).c'Y���]�1�}��l0���iXr��K���̙��q�Fݴ �t�M�d7,K^q��|�M��8l5L�3Yq�3���)��~��< k��� -�|IùI�����3�t� �Y� �P�C��ƪaq���(��녨a� �� �*�LK@��3!*�R{�j,�,� ��R������P!J�9�1�g`&P��a2B̪ԍ����m�0 9����H6,S��D��E5j_%�J�uRo�Ď:,�����W���B��N�P�k���RuT�D�Г� �;a��YռW�N-K�I�T�t������)��Xb� ��~32�r�X5j@�[^���L�J���v���<X<38�j���u�,��QE�� W ��JnW;ƅ)a H�f�ʚ3:(�EZ�ʩ����8���I� a'1U䠔���2b_�+c� l��V�����h"@F�>��V� � c]�p����?@0�<YGP����I�BEL��\��PJ�g5s�K����4�1?��X�^�����.�H���ܢ�Y�a���,��~Q>=�|̄���xQ����LT���^K�?P�`tk�q:!�#@�}@4��h�]SjݪQ�v�t �̘���[���N������腙��*���Yk�AZ(��^�K�`U��=p�� qX����qnQjYY�.Q��U�<���\~�60*K�癋�"N����p��zP9���᪗Ec;g�(VhZ��K3� X� �ds�BR��kbY� �8�+&P-����\���D��qU�����l>@F�.���A��p���+#�;z�2�W�{����q��|z����h4EK��U�b���l�U#� gr��D[a�v���-��A�V�8 �e��k?��&xk[�D �NK��Y����ƕ���/*�(k�����JQ�ɑ ��c+��If��hl'e6�$ ����:�B�v�Ǝ���ʵl�`��c���nlE�� 2���3Dab��7�:������-�(u9�+� ���\��*S �*&�a�:����`��]C��� ��L5@������铏ְ���HH(Nh���U;��*A��M" ���,Fy --�/0@HPA��3�iB��n�x 6� z��t����Sr�v� ~�8- [�Ad � Mz�i��g�J�Wqv=x��� � ��� 5�T�V����{�i�@�V�^Θ��|��%����`��u��\��A=|��!�-�f$���ľ�)=B��&gW��8L��07alQ����I����n��i�%ͺz_�i�<\�]�P���4��_ H�s��s�~3t��]�r�Au�0��Z�0����c �bh�� �F��8Fj�A�S���މ H(��zc朩2���̜�HF��k=��9�tg� L�S�� �����!ژ�bYc3����>M���U�y�j�ɣ�yc�R0�)�,4�� g ���f�����j�xbz%1�ǭuQ�X���>V�Kɳ��g��& -�=%v8�[�l$ �8 &��y.�N�����L ł��M4�s�����l��^Jj�������W� ~�Y�}+����]~�Ms#��^�jUS������=4ޔ��+� b�)V��g5UX>��a��Q �.�5�&>T��& �G;ce�e��1� �Uӊ�F��k��� �}вL��j]Ս �1�C-�d�'5�ƀq�mI��NSI�WM5��TxOј�L ����H��Sg�)@mQ>�MexV��׶�������X�P�eGF����y5�oS>O�c�� ��U5�G��������8k �X #��6@>�l+,.�g��b ��� `􍲘��k��j�@�'̰3�`�eB!������Ԗ�Fn!�y�P�K��8@�T ��g`2ej�b��u��[� Y�~^� �g��~�1�0����G^ B��6�Nj���>D���|֌�>��B\����c����ݷy/���:�3���:Lo5��I#ރ����L��m��b�]lJ�%��sM��i�� ��`��З�`�rJ�v�b�p��s��E!x� k��Kcߩ?���a7���S���1t����u�7^����=�-����r˥��)���>;��0�^9�� �4s�GqG̼t����:'��I�����%��yX)e���)��u��ED��O��6��� ��!nx5�+�n� �'�nPf_��A�D�����\�*{j��;qc8�w�;�)�Cx�$�ug \��x�����^�)��� ?Q��� ��)1��wa�gE���8� ��NA�x=���7�Vxo��N���BU�fw �}�p� @�L�����L�/#R�N#J��`�q.�p�}6����Gi��́��ޙ�6���'�H��Y�S �kK���j����dSώ/p]�mZB�j��[9�m׺�ꄬ:ߵ���i��z�M�v�I3�5g��p���!��f�TM�X�6���Υɯ����ɬ�:<k ��̹�0A�S^`ܺ ��P�֮ ��uV7��B�j�ˈZv|���ʖ�� ��L���>F'F��.�GҤ��JY�9�F�j���{ �\W���i4�-�� !=�b��g(9ӱq���������[h��9�9ct�k�p�R�%�m�s�]�c�&9�ӥ�[J�����;J�D��W@ j� �N���@�-��NP�,V�� ��)���ZV+��I�rUK?S�4Sb��|��E���죚Y Xt�:&6c��Uh�&�� �ch�/���S��Dw.��,���PI� ~@QC+�@��c�Y=t�v gXz Z�cC+Rd�J<���CF����1G�� ���c�X:�I�Jw��Wl�e��u>��t�@��>Vh�t���:�ș�g ��<�Z����Y�u���|2����2{�e:�9 �!���d��Ϟ�&)T<��*��] yݳ����)@�d+@w��11Z-e-�ZO �l�U�e"(����찹�u�¬���X,��;&�AQ)�X%��T��|��o K�o�;&��].ň)�&����|u�PpR��l'�](b�p�u4�Z����Y(������(m�֓R�:�[�aL��J��>�D�UP��o�%�!V);�w ���nx���Y��!����ʕg�1r��L�r�1s�� z�& cf�$[�6�z5�/0�f@0Z���!d�ܛ� �`�M�˖!sD�|*�ᬝM�@�+ i]O.����%���P ��L�*lطb�6_@N0�%�,0�����nmSv-4X��%^�r���� �c��2ܾ ����Z/�a*:'�l�dƎ\x���Z�g�9�tZg1:F�1�*a�@V�N��г�}��J����z� �``�������bs�0�u*5�zl�����U��R�j� �W�1����J�L\�t�C ++�z���PI��Yb��>�R�0�j)f�p�<�s��~�xn~-pUE�{�.�����0��p�N˲��t 1��Ĥ"���0]6�U�%*�����X�YXP�wԌ�xļug��Mwٴ6[E�#��iz�e���\-eP�l�l% �eT���f|�8�H���-�6 ���r�^>���B-���T�r,)x2��/�]xu��F�o@7q�ng��� O^�Tv�}�)s(��b�������3��� �E`���n.@��z�mjE^����K��j����W� �@�����Y2QR`{��k���"�s����<�d�$�}�v���afȃAȒ����� �0��,��lm`�Ԝռ�> q���- ��q� � K�r� z݃�f Nԛ���5z(�x�NVc����V�p��Dg������9_ �kQO�J(�| cc��h�����$�3�յK�0>C����k�fY%�Z������C �����8]������3��H1/S�QW��ru����Gk(O��żӍ@o��p07���2���Wqhݨ8ER/0�k�� V��u�#����%ᅲST'��2�&�1����D}�g��C-�@�w� S���Ӏ2����+��U9����G� �"6�kY2�����Wٷ�B����GeO��'O{�c�)$φ�����_�%�e�.[���蛸�;�����9��fqz�ƪ���-j�B� /�Jg�5d��d�9��j���TvN.p����� �D�q�a�8�A0�O�ua�|� %�L�XV�D�;�%ֳ��]�6��̅t \�OR�r�wS��-����t�īМa���S2��T/�(�'��4}�#��%JMRJj������/��y�t.}� �P� �������u������_�?� �v���h��=O�w �chϙ ���~�S��< L�)o`���G�x<>�a��٠�u�������8G]���r��7����A�?c�H��E��]�'�Cx�eJ�����������M*�m��q�X�ow��?H׵�ONEw�[d�W�|sx+�eb����$��o1* ��/^� ;���R���t��C +����19.���m���z���59�� i ���~��Y�w ���W��#b��d�H���ʝ�#�k a�il�1����'m�I6^0�7���ӌ�d�Sc&�������0�1���'8~�0�7�a*E�)]����ܪi����p ��� r3(d�v�W�V��JV�����Q)���<�p> A�.X� ������BT 3��;��ԩN.� bKi*.�u{���  ���Z��uJ� ���QOQ3�c��q^�HE��p ��K�y 񼇞�Zك �B�k��bQA����R�8�Y����җ�)�������E�T.����CoR����Xfa(�je���q@^Xh9�E�F R7*�n`(�.�� �Ԃ�`E��f~l�p��%bT6Iż��h�TR�d�&�+����*g̱5�� ��;��VMm�̫\�����%�)�N���kљh+)�����`VAs7�� t��b�7`x�Z.+4��B��3� ������F��g��`2�A�&���&Qo�5 [���� ~���������wQA�;��z<���Oud56'�����n����FG(T����j�D��#�, mz���Q��1����t������nx��?O�o�,����@R�ݣ�Y���G4ʇ.�z�����#�B�����\�P���g0Ln��JM�H2��w�����W��"Iv|��5���;g�5��-�s�1��L���:�����#���#ĕO@S{�0 ����<:mud����Bf#�v����$�W��j�n�{�U��Y���Q#JUxC�U������R�K��nx��%l��x�dP���BM]5@!�wP6@�J5��xL?�>�������aR. ����Y;�T��`�zT�p�=X�C3W9� ز�5:l���X �'#�n �н%|M#xj῞?���;P�D�X�b�Ki�a�;hz���R�!_z��P(V �<~1PҒ1���6�a��e �� ~B/u���o?���op �lz��A�*RR!��@"����}'���1d�o� �Č��@�!�gi;�t�WR�}�[�y~���I�j�V^�O3�4g�����v47�ä��n�/�Ϟ�[�.6>�u��}k8�m+�L�e�~e��[ѵ�qץj|� �:�πOȍ�p�Ap�s��?��^O�Ml�Q���m��8���5�����1����.�a�5������ �.wy��S��xw"��FPHx�'ÿZ��g���})�Z}�ڟ\��mT����������������%~? �΄�t>���V3K��$�R�~��@��n�Sԯ���E) l= 3r�*�oi�_���� �,�Q�D���� ��7*�r(��o�-/8XK�Uς�x�5ց����2����-�'$)G8 �q�������úC�6�A ^r1[[q��:�!s�E `�`�,ѧ���t�{�� O9���*'t�A%�xJ��1�f��j%�Y3i=B-��˨( ��K�uy7�>&�.(��R�8�KI{�&�p�R`!�pR[ϩkn&���p����*�����O��Z~��Oɞ'\j��Sh����I��=1�?c�O�,Tr�1٥�L7�d�\l,浣�C&F�l�*� o㼗1��e��o'k�V��z&�q�dˈ�sL�'-�&���8�X8��/����2��=�}����q�M�G�Ed��e�%g>� zqr<���h���6���`h�93Ϋ)��7�L���I�x���N����4)칍��9(�~?��gA�_�|��w:���� �|Vgb��>}��$5ԩO��� ����Ij���>/��>y�Β� eG �$� `�����@� �1۞�cb�l/39(���8�œ �cd� �ҢVU.e:-��1�0Q*�^� mF��mEv\��y��`0jh"#u�5�`�Pn} ST�FYp��4�tlXQ��a=;L3� T�2u��AA�`]��$X 4��� ԃ�}i���������G \�O "���[>�����0�񷏧.���o���M�g��߂�]t�b&j �K%��U)\1�n�����K.s<,�0#��B�V �[kM�Z�0�l%jX�LvS��^Lv�۔D%[Iom-L�Jg���s#|����b�8P#�h� ��f���q�4B/�b���J���U�t Q+a�ɀIf����:�@��$��<}\O��`� �'A�[���� ���7����''\����c�8J����PR|�s�:�+����N.�d+��aͲ�z�cL y1z� 3��Pe+����d��l8@�F']��0H�����)����´Œ4�Y���+FK�r�u�΅���F0�A�A�kV�jeg�F�E������sX�^�f2@ń_��QA�1�0�V#N�T%�w��.p�:�f�zΌ�э�iE_ ��������>|G��=%���r�4�0' �Bz��_�3�M�n{\�J�^���4��� �N���|K_T "I�c�� G��ֳY٭�l��mJَ�(�  �����|�09r�q7�O@��L�����,�m�%�8�|�R]楗F$��4(��x��e\T�ޏ"p�/�$@|��-9��"�M�W�+M�� �����&x�wrO!�K:rIJ�Sz�0Ea)�l��[��٦�b�^⧛��kUp�G�:ȝ־2n���:��lV��*le��c�8�*��Ś�e�<�&b~�^�:g"Wզ���q��I��z��Ũ�! �g�uV�/ J���'�i�S�j"Kԕʍ֦2�p���7�ˊ��m8ƻ?����.ٓ".{yz����k#7h�� &,�� /}mQh��e@�����Q�f�����D[�jz��z��'���*h�p}*�oa�@�ZU6�A~��[} �B5�� ��h�[���3O�aʲ���u���s�Қ6Z�(Lרx���3��z�j�u����Fh� G��.����?>�^�ߏ�n@��?W���)�x{�`8 j�c�l�𡠒t�D�Q8���L6��mL�Q��9��_o-E�f��@������O�dK�3��b�\*+�`~ˆZ2�u쭾�� ��rV((e�F>� �Q){�>ҐT�2I/��� �� ��k1 D�[ (��W`Y��agP���8�{n_�I~r���_�,��G���[��O��RjŸτd�o��W�/�H?�P�d���-C�ɴ�\�ZM֑>xV����*̒*W�5f/Xz��`w!��)Z��/}2��U-^Lt8�;��B+i�������<��IQc���X��w-iL"]�����>���[������(��4A�h&�}������ �R��pVD�������Ix}�e��f��x�X�����bf�6! �=�k¥�{�s � FJ�t�e�S<���R���������Vh�p����z�RS���<�41�7��9̗r����2Ty5ԭ��X��(�&~�\}���3�5��Ï����H��II ��,P�$&��`�U�; �9����NJ�%���/^(�DR�V*�eh��q`Қ�n��D�����~{���倁�� `�����Ч_D�EbD�1�c�� �˵ٌ��.E?5M��:��]�nl������=������?~�?��漢 d�o;�J'|z���a���>*C ��ErVQ�?�<G��d�B\�x]J!��w�!-������o���������G�� ����I���c�7�bO$#�|2T�?��yW�o�yq��_��m�K~��k'���O,.��_=��K�.�GUh�8<d?a�槍@���O��l�|� =��C��]��7�,!�1���e��������� ��v@ƥ_W/9�1�Y3�1��_3�ےͺ�ja�w����g��~�]<lj�d�T��#�k�pY�_.�4�� ��r��d�Ax��vB-�e��a����H��ֶ��^��/��d5��.�B���V�& �1���B������EY ���㝀ziv�A�N١bߕZ�����޻�H>�M���K��jA�}Y����!�_,�>A��1z= .4���d�� �b�5h��K�SY���J�s�<%� ����dJ�� ����p���%4��C�/2��g���9�w�P�z����w�ˍ���^�b�^�o�$$��w������ Hv❴'�d��g*qX� ��d�R07Γ�����l� �J��r�� @ �\dvj�i�u=O=�͔:�� G�`m5ϥ#@d=M�XQ8����\�vL=i?Σg��q��@��q�ʇ��&�x� ��1�x�3�D~*ћ@G��j�r���䠸B> ��m����bQb�8:��c,�B�;�,� ъ�!(�Vq,@v1�w��aU�A���kd�A�� �#�=�1!b��� �Q|���2o�� _�Qʋb�y�͸�Ү���D��n�Y:���B/؉����r� m����V��֢d�ꅌm�&t�a��O�U� ��.����*CG>J9�8}�M�~k� �� �}W��3 ��prm\� �ӱD�`����O���%���PTœ�%�U���XJ�k�败ՔUx�k' ��D�����.��n[qy�J#�m_�U@�*�0��o�4���=��*�N���V/X��{:b�9pF勀���]k�v<g���� �� .B'�T�+ kV-o��m��{� =�c����縮�U[�A�u� +p<} @G�B7e�]5�� @��v+�����KҎ�J�NV���<4�G`AW�:̀`��� �?o���P� ���[�L�K��H�n ���� `,�i{�ӎ9f)�� [(R�.f���Ή� 6�v�HtVވ:eŖ��agX�ڪ��Q?~��=+Z̼)ѽ�%r�e�,�cu�(��O=�z_0鋾ׄ� ̛h �`�}�z��ly�* ?���S��\Z��1 mO!�kX��"\zź�c��$h`'e�����+a&�@�gz�EVպ�\�Ӥ� ���gZ�F8���̿�=�s.���Ru�X�z8��,�����!���ߞ@�9���qm �C�� 9.{�^"b4E�� 9bh�)�\!:Q+α��Q�&�3� UI;щ��Znr�ڥ��Ck�Ì�T��l(��)�mg�����y���I"0 �8�3}o������E�Y�V���$Ɣ�,*���/�g�:� {.���3n״�층�w�4Ϲh��$ -N�S����e,�� ��p\*�t<�m*��PbG�N�[�i.Dͧ^���(\����bA�,+H��,�@ju��&:m�����q��D7�u�Q��dJ�=��X3/�I���P�5�G 4 �Ċ%��B�I��Z�L]�v�j����t�������zY�ݼPH�n`Pt��=��릦���*��4)�P�0W�e׍���<�X=��j�>u��@߹�a��j�.��2��=د�XR`::�BĊ��� ��w�h��9�QV��n��%��ݑ���!4�A�]�a ��,��~ ` m� ��B�yO�y@EA�J� Vu�����wPa0�����3�n�p@�Qv��y��' -�[ }4L꽷�8`8Jհ��s,��������ؔ��թ�4\>�ܟ�;�3�$����8��:6J�������5" F�u���q�К �%1�f.m��@���C@�=6!�r��{�p��hN0jO�=�<��Ux��Y��C�0���{�iB�$�Op�� �}������\ ��b\���%ж>���a�]a�HdQ�:�vR� ����>^m/�v<�x���������&�~�� {�m�;������s �2��S�����Gͨ��S�Cs�����)��a �4 t���f��(q� �ŎzĒ��3�spLw(E<��R�3e�d:+���=z�T��$c�n�/����A���>����� �����K�T zƩ��>#ph�aƆ�zQq:�'Iģ��kf,���G���D*�d�������8_vp�5� :��+��M�.z2�(h��R���z�>�\��U��w��e��Ϸ^|�ET��c�X1!��V* tZ��O���*5�W��P�%}l��H�q���6vB�HX�8p aؙ����t�� š8�t�TpQ](�����j%�8�ڳ^� &�1�,,=�^��;3�ǯ��W������ ��7 �"�!�� ���H�X�ii�� ��s��B=5�#h'S�t��ۭ<N����0́���Eg��H���am�J��H� W�H'�;�}xQı�6�v@Ǝ�pN��e���/��c{K�O�����b\��������|����V�@��`m=�eO�B���c��!���2�?���W ���� ,|�~��6���+@k��r��?�T�^jd��I[1��,�'� �?}�����[��^!2��Z����ݭ��Ȟ�3X1��~�k�S�Ȼ��o=�x��ݞ��ښ�z�+�ҳp5b��G�6 �ꥪ���_���F�����֎Yj_W�!�H1�� h*?T��%�8��Uc�9�����4��hS/���7�\V���s�'��7%��+p�ɗIF!��L��;fE�X�o�(T�@�4�J�a` FL�)�%��@M�� }��9��R�K��'Q1�UX p U �����0s^�K���9��+����v�_�9����b?���B�P�O�yI>�m]k��R,�g�ż:CK���@�z7��q�E�c#O��Ӆ�* �&���j��QTK[���j(b�8�ᆕ<MT1�1�O�3� <V��/]��ooI��� @�����g ��[v�^���9�7[���Y���^F��\D�Ho� ��)¨��X���ʅۺ74ݢ�����2�������4�%:�� v�����~�� Y�p�@�Ȕ:��%1�9 ��M�8V�B�f��L�(���Zu�s �+�����O|��� �ghO�t:x i�� �c�>y�qx�c���A��v��´��O�V+�#ǀ(�����0̨��H�Eb�2rB���+�qvl�n� ����g9�}������K�6�qh�_���g5�GT� Yϫ�G����YI�u�( �cp�7��JS���I�)`%V^��\���C?Al����$Y[U@@�N5�%&Ҋ3D�zF�f����࢏��NL��� <��b�2g(�{ �X��Qu3&����z,��#�Z���(���-}�6��pQL�@�1�P��1��q�Ljbf��@��[R�t����ȀH�B1��@�d�б���Tn3j)��M����z��/Mjih��^g$M�D| ���Yp�� X��9�%� �<vz5�MY R����@;�3V� ���lد���D�|xNtƞ�vl���Ze�Q �4�;�,���$ѡgl��f|��~\���c�L)��W�|�� &�vEl����B���|m���-�DFmgrL�ur��:�XSVa`�HwWT�Ћ��B�;�H1a��� ��#��n?�e�^�3=ƃC�|�1nu��b�0#ǩ lF�h�1q@Ze^��Ð�❄$�#�������N|;>��ߟ��^ =�w3�-]�h����ǭ�6Lِ��+pЖϡ�נ���&M4Ǡ,���4d����� ��/�@G��+G=bY)\H�C��'�V,��Y�Ūv�zO8k�p�<�1�T+>�+�c`J�)YPUa�x� 4�`_�c3�Ҥ�8�pO �eWD�|x�wBd�SSڑFȕOu�;�f����$R�^��;�l- ����J� :l��'��ʖ�@� ��������;J璂�RW UgZ��1ʤ�42ǧU� �U,řѪu�$�:W�d�Tk;( ,Uy��<�O>!?@:y9�q��\F����g̩�|��(+�)پΫ �8�YZb/VU1>���ř��j:���pš���82i;AC��fT�ܐ����a 6�y� �,B�|�w�i�F� m$�Xх��� =���)��@Ç7|A_�t��S�JI��@��G;I�Q�qMoL�#i���]u �Rc��_tN3�=.��Ok!v a�" :��>!?|y��Co� ��-�+���(+ ^��@�� @B��y����� l���Y��)�O�{"� Cc��ӥG�jBޒ*����%�RZV�ք��V`AT]]$�ܥD�a��@��e���~���2_���|+������ ����]< `H��@% ^�\v�����O�F"� z� g�t�܆�i��F Z��j�$�v�2����_�;�c�-r+7�PH�: ��k��@� QU^�C�,��xخ��K���|�(�g bD�f�R���]��QSZx#���j~����N�����1���`�KC{�@�J���؃X� #���m�* ��;�Z�3�QCz�.Q�g��?T�� {U�p�}��,���n��� �_^�Ib⥫x�� Gz�X�3��v��X�g��I\ �� �9/�IB�زg�J^1���@���'��Iġ����49���j� ��i+��� �*��V8��#��Ǎ ����E�{�OZ����:�#��p^�� .���P�s8P�������(�" �v�0�`Ctq�0; �5�N�O�IЦQ�(�`((O��xk��� �qD.��%�����zq$]�;����ap@-�=���=0���'@B�%%�"���9,E?8�UV��=� ��C��O�!c�l����U>�mP�ĨS�\�=�`@��'r�&@zO���#C� /Y��w$ �v��l���ۿ�q-yRGe}�!��T|x�4^ɛ�~.�.�eW���� �pz䗶��Ȼ�֕p�d�l��?��/�}���M�dU~JQ���nZ���������J~�|9���c��?�M��,�gW��|�[e~w����oחfg2Y�`?��y@~��|>n\�N�W�W~�S�������� ���>� �w�(Y��,��% 2�p�ܸ / �p�ܸ2�,�& �p�dd�n�,��N����dn�,�L���dn�m?�C�3�,�|'`&����ddd2o@�$D�`C��w�A�L<�;��L��,�\����X.�Y�|@�5����rY�� ��R�xCW��F���]~��5<�;��L�_ge�W.H�\(��� �e��z���5\(� ��S)`��ȩ���]~�8o ��Dȳ2���e��B9�~��1��ٲ&p�,5���5��Ms���dn�@&s�dd27L@&s�dd27L@&s�dd27L@&s�ܸ�~������wv`?ka��\Y�"���D���Gwguw_�����X�@��������,� ��p-`ۺfi톣���b]Z����x����g8k i�pb3�yL�� ��}�����ד��d��M�,������y|���9Y�"�����2H��I � ���1v�=�O���dž�,g�+! ��g_�5�/^rz[�;�_r�A�#$Rqo���D$g�'d\��;�C꿟�l?-�T� `�<�}��U�h����r��n\�w?�-K� r~�~�V{,���w��O-�L�xHw�A�2W � wq%�_O��zv�+������>$烞�?�\ Y琸�Y��� `���A*�Cxܐi>��r����I'�w[b�dyޥT~/o� ���ԟ����,g��' ����~�X��V<�`��$���;�oLK>g�k' �����to���V�V 1+�_��u�Q��)���wc0���� WJ۵�5[=���/f()Shb�u�!h;����lƗ W��������� �������[G A��Ѓ�Ѭ"W̛���R��7�����8���=���OPoS p�� �5� _�Ȃ��# /��^��H�[� ��E��~����E��(�o��~���7� ȼ�5�(X�<�J��Dk�I���D ��S �qz0�i�b:9�p���1��R�I�N@�h^����{�Ϊ��&�S�������Vn�*Ҁ��g����`)�8Y�K�r������v{��g�V���Ej�' �f����o��Ҟ�9��ˁ�˒�I�n o�4�� ? �<�� @���R!X:o:�D <��Ҁ�aC��'��.{��8��'_m$a���^_��}tO�Q��{���/#���Hύ+���2u ��D�4}iX�\��t<���Öe����9�0$��?q ��{O �:�p����o.��O� v�m� Ӧ��$�`�|7��L�y��A;g��� � �4@��6{���<�f��f��#��Z���+O 4���A� �� 7�'Bp ���fH]~#��73��~Uo�ن�Y��3���>�� �iC�N$x";�ܬ�p�3N����_ :#�a�_hؓ*�p;�4V��R��h�Q�A�6"�"�$�[Oz�"I�F�J�����{��P�dI�XWZ ��Ù��l^^��/��e��Ps����} �s�:��U�F����W�̡�H ��!<�^�e�'�Y�[��N�yhim�_��� ���]�t�d�6���9��� �y�P��� �.���q� �[�7sf��c�����a&�_X���l����|#�x՜a���qY��B��ׅ�f` @���^��p�5�G�a͎�������?ü����|﷤`2��Y�%���ݎ����U�`�,�Xo7XF ü��� �U~�dT��M|*��-V������b��,��`�71��4����&+�+�����b>��a/��y�ZobMj#\0�{^{.�z� �m�*w@�#���l��)|��+�/���{��O�k � {R� �h/�,�L��>D�Š�yh����%t�K��6��d��on�o��z^�N�J z��K���IH�A�b�Pfr6�y��p�8�����$�n Q���,���l �>c$��.K6�y�H�z��ɯ ��S�_����)��w���Z睲���>�Z [��0���: p��=��MY� ��0 CJ�l��`�R#�kЍ?K``��o�CA.c�7Y��k��0#�����)�f�,�&�0��7��} ��o�ܕ���!��F�p�`���U�i���%u�{ l ��Š�K�6�ݼ|>ɃY[$J�C x���M�o3���Y��ɍ��0�[�d�;��E������� ���w� `� ��1���<����Rk)lC�u����D[Pk-Ә���q�FJ��Ϟ �S@ �`y ��\,�:i�rm�n֍I2v ���T���FD��*���7�)���;|@[�/�g���q ���a�Q���� C��x���Z���O�S_�s�x#�q�'x��*ϩ��� �?7�bY�SԪ�6K��B ���9n�>��$>eRw�9s�*�sK,��+T�4���)�qCM� �Z����q�0����~�?�5��g��u$�|�| ��6��x*�a�y9��]DW�k�+��=�r��4v� �� @���DP��1���_��&�k04�J��M1�^���ȢF����B֥@��}������|v�?i٨�T���U �Ez�=A����� �>�?�Cr���|���('*6��TR�*�LoȚ8����0�%ҙ�@�� ������IT�*����<�Zy2H2*d�A����D.��O�*���.���x�{׶�8�A�xA�,u�D]���xHY�g�q���v�q?(��f(��v� bb4�j��_���3S�/�2;x���猲L�e����a<��+��'� ���hfh.]K�R�j�=�? �H#x�x�dooz�����e �`%�F��XQ��ښU� ��X�s�Y�M�bZW,}9��7����A��d����|�h�8� ��:-a?�pN���e� g��`*�l�(��)���Y��t{�t��E�4������L��3K�R��� ���@-@�Y��,Ut �Q�R�B������x"��%�n6�������l��=� q�U�����J��u7H]�r8��\���մ&��C�������#5�<�,�Y�,�!p#E1�o���B�33[�ZK� �S=��<1�%�����!�����\����b�:�0�Dv@P�!��`p�,ql ��� @17Mo�*��r���'g�3cYؼHriTȋ����}��0�Q8;`.��� @a&yh�1��l���_���5�dmS�S�l|M|��ضS)Z��0�[�vș�*�sP�M[E�� 5�˸�G�R��ب'|��I̭���F+C�X�j�T�����/ �����.4a5ۡT�_�l�E�`f�� �����nͼ�{�����l'3���?:�޺2gT��.��k��Ę���~9����aZ.Q!��2\IM\��t�� gqf/���Av1�@Zr)�<cb�������"KJ�I�'�{ߎy.e���ƣ(�(mxjnBVQ�q����:5�K�M�bC-�$XS���Y�3�� �rݘ���5�V�i������N vS���<R��;�r��n4�Զ��A�T������&��DQ�&H]mA$��3�On�lJ��Pp!r�� z^��#�1V��AD�nh"�վ�Wnd�D,F?W������|�F(�r�M��3l���v�c��e���֬������f U? �9�Os}���{ �;@ �l����l 5h_�Ud�� �ڎL%[c6K��7�ocș�qb� &9�l0���h��v�K>O\��B��֑q��b��� -�2�5�%���\:����m�k^dv Fb��)Ug���3�-�W� � �-�) �A��@�����*):��� A��\�)��Rɮ��[+7�}?�2������}��@\��8U!0L�Q�iJˋ 's_O�OJ�iQ�k_�ʐȅ��O 0N����t�u?�#�_E��@�l4��x�[1�P�Ǽ�Q޼&=p/�P&�㹀E��;�s���Yn�O�@Y^U���J@G���o�� ��a�Y�hyb�����EZ<�>��R"�D!e"b����)��x��IG����o|zto�#`^G��cᠰ���>��� ���d����>�^q���[�SJb���Vˆ���7^���c���\c��8�/C5JȈ�vو{ K�cL���7� ��^6JD�0X����ׇ��M�vDq ^q`�u]~�I��O�'��Z�_�7�d)�Q����1�x��y�����-3�v�H��pD)��m�L��>�����h�5s�dKװ`rئ�a�@����������v�+9{踑�{�Vµ����߬?�<���nk��i�/" T�E �1 ���@�J��\����@v1h|#�c!s:�B��P�.��%*D�S~����׹Mc�i/��:���/x���!�|S ���e�Cf?�OQ�>�HT�o�K~Ÿ���UA�\/��wW�{���߱m�̔P�&X���Z}`a�TY:��mT��X�W{����ђ�����t��+H�άnF���P]���|T~�� ��j������ �������F�0�k��3�3�!�5$�_�w�F���|�4�Z܆�‰��S��;!m:���9�^�i����y}��ߕ�˝�G}1��=�q��͉�ށ��� q�p�={Z!a<�%�} ����}���=T�A ��!V�O��)���$*�ɼ���A{:�W���U���s��w�'ʡ�}�c��=��P����m�=�Q�$|s���pc[��XVA�c��A� �^ŵ�E5z�"�|�B�}��yO��> ���C&�l�\J_� ۯ���:W�J����ՠZ��=j��~�-W��\�Vច�O��� �O}�@�#^;�Z ޷�q�W�9qw��u{��z���Ն��º�V�G4'��y�[}�7 ��ޙm5�s[X˒n4do�}�C���_�%+q��]?#Ϣ���cZ �,�Ji8 |2XW),�X��Z��@/P ȡm'�X�?�Ыk�9�J!U�>Mq��{d>����1�T��� ˫�3�j[��ܶ?��n���p֊�[L��?�6gL[��Vb�^��M��ba��M\oMg�Nmۦ���g�Bb�����"��){b4�q�\�3�j��y#r`2a!��ԃ�`*%&)�V�Y�al= �|@U �X؄݋|���)���"��<`.�a,&��y8UaX����* �4C,���/�&F�}-Y�]�&i!|+}��.q�����);k�B�@8Tz�BX4��b�칢�d��2"L"58v!(�K���\���%E��|+��*�n�H9n�! ̆O�� ��* k��'�&�nƳ0��V�>a �Xػy����@�ch!� vt�pS��b+Z��R�vu���0� �s"T8�I�z�T[�����~7|���B4��[#�$&K�P��-4M���yE~/���:�bF t��,�C�нr�Vj�)�Ƞȝ��Wz�Y�d���*%g0��p�hk��f��qr6' ;TB�{�0�^E|7�p>�Ȳ{d^\]j ��Hb��`�B�1�e��c�a��̾>�x)BGA��@�4\��M'B���{���"^�@�`!0(7�0\ �y�G��g-߷cp� ��I�����.υ�FFE9�;�� �3;����n^�=�9����o AOF5g��K� �2�e4����"gA�@Gu�d~#��s�G?j,PaQ4����Q� � I��a�@���y$¶bB�L\˖86��$Pd��u72Js�8DI��(5`��� �Ɓ�V��@�5: cH��B�w�FK��0������@�!�@5���6�݆�V",yz0�0��؊�b^�;�!V��;��1΀q#B��#>��s��L+|0��8���J��u��j�3꫾&�4�a���l�%X�w@󙃤��E&^s[�.�h�Vr>� ��5�Ud�� ���ݶ ���H�A�CD�M�@�� ��n~���c�.�K��-0��XN O�f*g��c�9L�R�����i3��;+��R ��Y�I]�A2XV�� P��}/}�� )��\M�% �&`g�p�釓���mb��c0r��gwN�s�X��1�Z���Z �����J�N�b,}�:�*�(��;NlS�� G��B2>�����B��$t�xC�Rw�����G@�����rk��k;}�$����sB�lN'�1������"I�Ԕ�� �-���~����3�������/�I?)^> �)��o"�m�8�ڽ�����`�W��5��������2�V���oo$�ί���b��@}n��);� �ՊL�w�L��G�y��;z+��/@R �5��?��N��/j`� ����}��'����}9�#��ܭ~��~�� ���w��ܭ8����k~��q���E�p���� �۴��ɧeD�MkƾE��p����°a���ɧ��t�.����������.s��$#ݦƾE�c�xd{��:p�p�@���x`=8�w��:p�p�����-&H,��G���fR��m����c��HE��*�i~ow�zCn��=LֶU�~'9�v����CtSi�<ƳV��~����  뼴��H��xQ��]�&s�%�����;�5��:p�/@23�֌�%@b�T ����1�X�6b|��˓��֭��5���{O�1��Ւr�o��\��Ow]� d�ښ�t20RJ�\Ig�N�q��EX��G�m�`0k�y��B�~:~�Rk����� ss��38'���s-�(�R�N�aS�����/'��9�rZ}�D������*�+��2�cǑ c5�Yi��T/S�d��Y5u��z��XH��96���}�z5�{�M9 �:(T�_��A��S�;�U�&k�k�Y�n��ʎi��s�%��T��yT�s�{�5]MӠ�0>�4�' �j�Ff�����У���4f3��%�2�Q9��R֨2 �2kS����rT���`�I���� �RdZ}��p��l��4��f�2�*�@�2�R�:̚O�Re� C���Q����@)���(zR�>!xe��E��G���f���3�9�)O���F�Q:�^�Ԙp�M���k�E��kk#FJ�x��p�xk�}�NI���7��IgJ��2��,�$;UhݚJ���F�4w�1=Y�E�-�w�H��4@�� ��**�Œ�A�qK �ɴ\�c��@�s��Mʠ2�T.1?J�(@��flPE�D�j�RKrNW� `<3'�s�'��7j`�5X�nO@��ar2)M�����b*~@�0�2�Ό�4�i��T�Z��&�g ������� ���.̑{S�&�D�Wi���OW�n_��8�K�u�P'<�M%�2!��L������e�캖���N B���@N�#qHKT�s�舳�g����k��=�|er�C D;���i� 3��"e0�t�J��m|�����3ێ�H>��ɭU�Ϯ`�W�'`X��� 6�g������Rx�j%i�����W�-R�&��v�:� Xj���A�}r����{F�����a�t��R������M�^�_��) �v�v�A�x���K����e@���h4�<�I@�U“[��Dy��+�x�|��'ID:����Ո���}��#|`0k�u=�J�f xS��|6�fUAc�4����k�fkz���Kƒ��ɦ%>n-W��<��i�[���ZwvuV^�� S6�4��U �i55ƣ���5��2cZNr0��\ �ی뵌���~�>�#���zFO+�9�LII�JA����"��B���S-߇�>^���:3f]��Ge�,��kY�*�VU����#��T�V��]�ڢ*��p��޾mKc{�ޚ�T� �&x��sy�+�Z3��:*S��P%j4S��P����U����=�C &��̯��d�|�y�@ij����b,|��m��� 9��4h:��v�3���A77,i+)�6a���yR@3b�1�z�9��M�\�谷�J��S%ӹ`?[���)��6�1ٌ�Y�F�<w��Gs ͩ����M7{PL�bN�'�Hz�r?�X)��1�s<6�X0���`���#]?���v�q����,���|On�\��-H`�~a��'o���K� 9�� ��@ْ2\��Y��B-[u�����Mo��9?�z���21r;k�¹d���3&of��t� |�<��)6����3���e����G�Kn�p�̃g��t�o��8؊�Wװ� ��/n�/�s`x��ʱU6b"`rz������9%ci�����(S��s����/���_ ���'�"���?a�7p��ӧ��������t:�]��~P��`-s��#���V�|zy��ߓ��]� 6 ��ӛ�C���w&��xo��#���1����3���o�q`��=;��o <a�_IP/�B�r{�޽�^��p�;�H'ܦ�쿉/?���1�Ku��v�w�@�]�߽ �p�4��~~G�eI_�j�/�G�����@M��G�ݶ;��’T�A<5��)T ��a^:���H�)�S��f�ȟ�������5{[<�_���/��=�?{��*�`9���l �%!\�����"� dr��kwz���T�H���-��_Vn����������Xc�Ƞ?T:�j�•�"�:�����n�a�3bKRU�B��W�I��m�΍��1�F��h3�;w u/nT�"y_� ^��ѕ� g���qz���1Q˯-�Ծ��>?������{����no�YuIJQb���v(����k2f�mΘU$��*�τ�'#�bח$U#翨�Ef����^p"�)Pc�_��p�n���΂��x��eC5�t�4��[2�n��5^����b'��T���>�b’�D����„}�f�^,�O�ѿ�8F�H]�>��z��G2H7�l#��@�k�p��:�R٪��Ǣ���55Cz�I���Z�JMU�ɱ�PW�D��\�����r�u��������U��� _�@>� �u�.�~��X������/���u�<�$�b��%9ԝ/�m��h2� ���L@�p:u��+7�L��^���s��rFS��k��a)m}��\4�����xޟ��!C� 5;���Ig�zPMiQ��S�M�/��3-����u���w8vji[��Uv�K%ݢ��_��ǿ��|��_�: �o�h��k����v����?Q���ΰ�ın�;�]I搛e3�eD<UJ�˶=�\ P�~F>a � J�:;D��/��\�#�ѝ̔Zt&�SkL���͐o�+&D����^��Ɋ�]M_d ���R<��2�"��`ٵ�:q_"��V�3 ���Y@C�h� ݑ@ա� Nm��m[j��!�l����.R���5����g'����D'��j�v*��⠢��}�����@v���� �G�j������q/�IF�z��<F���˻�A���g��0,m��.�M�臎 ��L�9�0d� z�Y���� �;�*13XÏ�OF�����Z��}w���>VcW,�����Ȍ�Cc��T��u��!� 1s��d��X�ҴRt�k��R�� ��n�ڹ�Fr���>8wuD�� ��sg�&�zV�[���&۴h�\�Ԍݏ4 !E'M'�tawV���`{�Yo�{�38Xo'��J�kAaʸ@�9Ƌ������/Q�u�������R�ň�ū��dm��~k0�K��%��5�����0!�4҃�������7E������0(?55�?��EE+1y��Ԧ��i�o����1?8,�k�-N�:ۧ͸`t��H@�[��T:��*���Jy� �w�4�@F�ߞ � O�N�%�4�1DĮ�%w@SbI22ق�ě=t�h9Ʃ��"�uQbҾ��.8���뗤kg�o�@�s��v�����'�'��w�a 4ǯ�Nj8�-~B��k���U���6� Y\ƒFddL���s�=��+k����b� �<�o�:���4�3�z:��2X�@�)��è���ZF��N4�~f�/2K�����V�s�< S��g &Όi`�0`#�4�s�16W��r���[��qZ��|�"��PxH~�eu3���J�����`I5�Ld�"ţZ���&$�a��#\�a@���� �yR| �rI�����J���}�&E�)�</x ��\��� Oz�nK;� OMKb���9�t���Y@��)��8�}e7ki�:�hp�bM�y�Ȧ��s��i@� �� �{���^�^�B�s��.���l�d3O� '+�M���h'�6��E��As�� �%��!��94�G50;�m�s�����5K&��4����'#�lˆ�ZÌ)=\���t��|ۆ3 -nbU&�h;7���˺�g�g���Y������ ��Ӓ4y��I�dz_�@6ƫ��M�i�$W<4d�2_d��gutnV��0����j ��98�K��[�䏉3����wX�i���k�/lL���̩9C����$��M4�,��T���4�R|3�T�*�Z�(�@M���̦��'��To�d9U�|�f��z ��k$&�Ԛ�2�Zt<ꇦ)T:�R�������J[�{���3����\5؋w_n�[f��3+�6|�z�t�;n�3����Ͳi�Rǂ=����bQl�+�۩��l��6 ���S �۲�]��iV����$1|%ɿ��F�Z-v�JS��d+��>�W!��#��YR֪�R�%�-�O�oh�s��&�P�ڟ���g����S�򑔥�BKѺ�b�/9=g�6����Sɴ�n-�:��J��л�4ݓ�h��B4�D��!ࡩv�b���(�}�/ݻ�c�<�}v�B�)��~L����m%������Y�ө��m��ڇ��b�?��~C���Q����9���^v|@�Л~��i��x�}��'�v��8�O���1�[���"�]v��}�����{�Ʋ`����9�Y��=x_ys����Go,;v����{�Ʋ`������Go,;v����{����(�a����9�;E��}e��=xc��P֪�E�/Q���~H z-Ro���`}M���ge57�f��w|-�e� BUk�~v"�6��?�����7~�W�| ��cVj��H�[D��H������A�J/B��Z�I�G���D�w����C�7�S4˜��ti�rNxKy�jc*1�!5 ��!=��������;��N�y:+��d65�մ̜�Z���C���_�����@�("�\�M~j��H��%�X) � ՛�B�{u�_D�1�|)�M@��ݔ/V��:=S���wK��1�>�B���3� E��mz��� '�$�'� h~cP]Z��i*��I/E���T Η~�= t?Nc�=����!�t�5N&�{��6ʬ�F� ;��U��;\4RlO��df���e�I}4 �%=4��+��%��Y���3��"��Z ~� �X6�ۼ��饻&�Vk�q��ā��i,D�>��[�6���cj-c;^�a̝ݣe̖{��|e�hGt��.�6��rf(�@c� 1��v�|2�3�h����fDcDE;+̬��F$�_����Tv�$��Ġ��h��i)Lc�Fu�Ô�mF��΅&c����E¥_����qY�ل���#M\05Q����c�Yaւ�d�֊�#@�,̬X�I� aj��Ś��2Y�����67�M v����t%*r@h�&�}��T��8��DY ��he�{�ڸ}� �U0-����v�2�̇EԤ��}��:�[���O"y�5+E�L� 56�A����(j�Q����c�L:d�n՗ޜ�1Q��5������a,0�c����Z�Sk� ���Ž9|c�*z�/t@��rmz@oJ��Fa��,��ִ��F�U�u����d"�gmZ�ˠ�x]�t4�V{]���ID��LE7Qy�+�$�y'�����U,ɕ2%���{��C�j �-SQK���2"��<� �a��ѩv��A+��B���q`o�q0�4���@c�'����(�i�h̾�m9�l#~ԉ�*�-;=@��7��-*s�JXt����O��4��ٱ1������h3v��_Ŭ<�P�-N�����a�El�1VK�����= $�����}��A>E�v<��% �����GQע�Л��C�� ݴ�ᓆ�/#��.v�Zf�g���UB-�"�����`�@JT�P��#�m����T��*�4�i��.ER���1���A d��G ��Sɪ���y��M�iG��Բ������y�Ծ5��t%V��XHG�j"э���H:Q�b(���Ix�M��#|c� 3���$阠IC95�I���̒�tf�a�����􅨮���v.���b�#c5AKpn��S����ѫF0�!nwH�5ta���v�aJ����C�v>hkj�r�p>0M#�zMc��yk�nMˣ�Й]�)e4f�PS�EXl㓞�� X@6t��������ݭ))��I���ʮ�%��4i�jaʏ"�D�\g�J�D�D�15DLO|eꆱA��?���JS�F ���98���J��-0Y� ��u�@�a�&.�2����2�����~큷��y\�� d5�>���g���F���Vr�(dՁ$ø�N\�ɉ�饇=ursO2@NX�'��v���G�ԲC+ ���<c���<���1��DE� �:���"*��p��0�[��� �O+�H��7������}dҜ�G���,�u?,N}d�� ���i@�<<����ݹ&t��_U#�� ������ͦ���> ��P������:��J�'��%dL�1�T�8�iL��dqN��{0���N~V�#���d�E�/�/� ��>{3�����2�S�k�}*!S ���P��0���ur���5�o��>���қ}��W^g=��w$���dF ����������$���Ӎ㲏������m� � 4E��� �u��E�%����)�I7%<��F������)'�ٜ>W�?��,�w>����/�:���������ߕR��T�O����p6!�����vB>�y�Ӵ�#��,W�O�zT�QvQ� z�1^_��*_�s�t�Μ~�O|p/j�@~���_e�7��� �$���X wU_��C���#��~�I^Yǜ��� V0� �XD��V��ڸ-3�۽J�� x�:Ă ����u3�Rhb"/�`��w�lٞV'7Kx�\]ާ����\����D�T8�����\����pA����$����lZ��"ۻ͈E;�@bYn���:m�tU���y��4-k%�7�uY~�\#�UYi��H�k5ȶ,ǧ6�犴���۪�jO�����gӭ,'�}1�iJNm̶Ȝ<��[��Ni��7<N�9�Ѭ)��i��R����RK��1w ����+�n.41WF�� ��Ǐ�st�'�\Ȧ�.�!o����@�-���V0�z<k6 ��j��'l^�9�T�* o7�:0tӯ@o��I0�ɦ��N��ݢ���@�2�"�,�V����Z��(�D��5�H�>M?��1A�26Q�rC1yJV�2w�/ �x�B��<s���骖���9~��$��rsL,�ԁtj`�Bģ�1�A2'���v�m�C�p�-񊩚i�BSZ�x= %�cƒ4)�$�bI-������ ��;΋�h�;�!�$�0�r.���'j��8�������mtV��?|��H�bJ���j�ul������������[�֧&�u5ymIh�m�j�~����U���V��Co Rl��Ҳ����D��{� cǁL���k����`�`@cŜ��H�P(�>�jcn����>eX�,�ԩqeս!Ǫ�ƁT���ce�!���8Dm&��92w�89���=���� ��*��h��n<wخ(�*��*�� Ju0-Q�Y�w68�C���k����豧v���ْC��UWliq�#�� G��(s�2"�����~"E�X�*�����gTʱ����~.Ho��na6��v��J�i���d��b�� F�\�\�ֽlD�o��V4�} �^�{���[=��b"�2d�TK���z_��(Vҁ-fV��L �ߍ+sK�$��ٯ�g]����c@0&�Xâw̔�����%�pR,<"�ZT̂MK��)n���+��a3^��Ciˏ�t�O+� V~5 �A`a�@j C�sJ >���@�c�;�T�R��D�J�W��@-��������A����M��'�,l�77��6��==� *��ӗ{�V+@�ڕ�0*g�h� ��D�n|��o����ڴT7-*)K�Chg'� �Ǧ��(L���ҵ�ux��t�%�uGCS�y�������f���R8���K� ���'ũФl}���k�M(6|�{?І)�t��z�b���S���+��9P2��= ����$T�c�Ɉ-�ydA%g�@�'�U��;p?������@u\�'�c@T� glN�J��"� ���(�R�$�'��O!�O,O 7�\��C���k}#���c[6��P{ ���n�V�PҮ�1���ˑ������YuZ޶j1��'��6�������e��K ���%�α��53�$�C��ǽ~�a�*KR�zRNޭ:���>8V|D�أ,x=*u�c����7�;�y�9�T������URs�b��2n+�H ��Z$�����5�:GGK q�� �g�A.y�_�[�f���=0�M⇵�v+[%\�~�)��=�``�a��N0Q�� A�V���������(�@gת�@~ѱj�-`>�r��@e����ؽ�`d���G�c5��S*�)�8ǔ����I)�����^��ܳ��s�I)���]�����迎�bO��XHC��R�y/��q�%w�9�5�u��z��V&(oRR�c�Z(6S��u� ��,X�Ô[�\��R���sK*S���JmB��P�|����6w�8�)��~���,?�E�*�@ f�O�d+%���[/�R���t����omA7�"`�#M�m<��Z��v��-E������ztvⲚ�?���%��͈�s��W�sb"P�w�Ź �q�)���C�ط�%���:g�� �v�tND����(�Bl��V,t ��� 8uKF�{�,^/���@b���|��/�͊�:g%R_��ҹ��@����>ЍiыTF�,Z�- Q8Wᘣt.�0D��۠��N��%g$Dw�8���.δ�`l%*~� ��w;��77;ג�'[� ȴj����؊vf �Ywk���}0��f��8@�v���,͠�l[����gۤ3�r�@+l��:�kqI)�,)�O))��FR�>~��!��$�~Z���:'�����+Wݓٽwa�Ǽ ������\� fJ�{�$�<�#�T�{NS� ��$���j���� ��Z����t&������/��}�������d���O�}��6�\���Y��6��8y�^o�nx�����۴��c�{7N],�~�����H�8�2չ�Ti�B��X7x�jo���M�KO�-� D%��'�/%�w�}��o�����.y�}���R|n�a�k�]�M�>��OD~������@�[�f�����o���.�'���b~� W�az �ͼ@����.x]�"��� W���pЎ^�+�\}8:6^�"��� W���p��>X.\����+�`]�pE� �������pE���& �>W.\���_�HI��+w�/U�҂k"?�B�~c,}py�g|(.��`�,�_6}G]� �e���� ��6�X� ���n?��[/Ļ��%��`l,j��O��P�>�W�b�������G�����(:�h�I��J����9�w�K��m�[9|��n�sZOu[�c�J�6���Tѧܕ�� �'�&�ՙ��q�/)����=������y^����o�V���J� �:���{3t�%�]iqՅ���q�m��k�g��K��7�bl����y��&:Y�Op�<-�]����A ���B'�AF1��eΕ�:�9�6#y� ?ׂ��b֤�D�Ѥ�4�pyr�?�ζ�Q�i� �PT|���?|�Ў�٧{v���Ljg�PP$Ux����|s9^o�D���s�ɛ�/� ����{0��W�Ҫ`s�|Z� ( F}^�� �Sg?; Ǽp?�4^�,�︜��ݙ��R9J�y��S� �e�Y�����/��H��Nk�ц�f^��5W��4��F����'=m�ZvT.0�]D�(�qc�q��z�Kɾ��2� _(��ox=YB������$Inz���,s��^�W���׎MZǿ��X��"ήe��&����-\��jw]��i�U�ڽm'Ķ��ڌ���{[ �k�]R����������NfhL¨qg����ـ�v��c����o �ϡ^�X��<���.��H6 ���h�ّ��0����[�p>ja�i�{���EТb�zb�[��4�a�v N a�Q�]�C_q~���n��N�3��9�Ob�4KNX�Fgx ��M`i��Xt��^���A���:�|Ws�K��IQ�����o��W(� ����R�3?y.Fr�H�6Edd:r�( �E�g6y�RU`���?_��"�1G���Mi[���6�'��b']� � �%�$�=��M�7 �(vێu&Z~dbv�����a�e���WNTн̢��*�#�WF�v����+��9 �:,�tϔ6�ݣn����$V��Y}�U��2�$t�O����w´jۮ��JL�Efz��nz�n>�V.�3P��!$0���@h���澭� �8�&G����xj�cm`�t,a�Z|}G&�7����[`JHE1g]�����&뎝�2`hY�HC���l�`�@��m Z�� ��� :V���@?�7����n���T/�%�V���F7��9�Hm�܌ӋVNό�,mtG:�j��'(�������fsS1+Jl0����Y %+8�4�c����ج� �EY;�:���;3sL�z�3�Y �)4�2�=�2EB�J �[� ?�'E1q��V��So=P�5�kf�b� f��\����Q>�a��2�@�+4��Ec�`%�dr �J �ΦW�:/� FT�8&�R�*/2J����a��\WTjt`�5I��2h�m[0 �` M�Z�pN+�r`&]&��}s|�@�np���>�̒V�2B��p�w���,��#���K�L�,��V�*9�c�'~�(�t���^��vϚ��/iЎ��r��Ɏ㴔D�ͪE�%�7�E�������� C�� �Q��<:�ȡ�=�X�ʼ�%�#���p��f�Q�ef?. � %N#<'|Xm/�ZxF:=gε��2�N`�nt[83����]]������7Gl�s{�������q�����eGG���LW���kC�R`��>��~�n,����̍�$}���du�R��<��(�8"�{�y`=�����{w�]�� ! � @Hw�}@�J� �W� �#\�Jv&H����W�5�4�q��;czl�z��E�T3HUo=mE}�V:�1ʋJ�QGv��+:]� ���{1�GW�$*�&�H���u�+��lt��e<C�x�6ۚ�p�у���*帍����X����c���M�L䅛�����8uE^v�Beu�4в�y�_`3�ȃ�yѴ�)@��y���v �FG� ����K+�K�W�)���3����VR Ĺ��z� �y D�k��;��DpDm" ��֛� �9��M�*���dB{F@x U e{%n���f���^�A/�U�7��vFo�6}��G7� �2���&�l�.�3��fh��Zp�Ea�Elϫ��*@^��"��X�?<�uE,�x4O+���Pn.��h�.H H�3�2�F�YF.������� ��p��qؙ|�hL��Ѐ�ˋ�SL��z�DU1.�$t��=�8�s���Mq���.Ј�n�o��y?�X9Jd'{�4·���8u����W�$n�C}��w���'|�KK�����9 �Ț����;�>'��wB�YM��g�{8���W����@�0�F��@�S�/q O� k����S;EC���(*NFP� ag�7P��Ik�-�|>4�+�ͱ ��G�(3�&�,�頃�_{e�pءG��G#ؾ��T�ʴ�~��|�� ���+�ƨ�jx�^�� �wN�s?_�|����7��Xy�,{5:�~k�=�Z���D��-���o��{�[�j_�o��+K,TQ�`h|�yF�C++ߣ�T1��]��>��M�;|�5ø�zY�/_��X����*_�����.i��~�v`����}�cy����5�P�f����)��w�AA_�?^n�CI���4���/W�k']H{�`W����<�ɷ]MX����z;0��@���������I>�'� n3��l��a�����<��;�m׳;W������׺�� e�?��2g��t��P�yu��X�X� �^��c��L���_���*��x�v�^� QtW`����!o[���p��q��/�� � Wҿ����hˢ(��\���g������ʢCE�=�m�3�@ދ/^�U�\�P�1�0��������k�<rT�&��d,7���׳���� �t�S7~w��E8���D?@��P�Xp�2*����)��?^���.�<�����MW�M���Bi�K��(����"_��w��9�U9�UQ?�<�d@���}�W� ��>_?����@�y��9_8�W�\���w�Bޛ�e�"���W�LSN��ј���"׷5�k�����Hߟ_+���4���u���m3t"�WM���x,���!&k�O��ޯ�w�"l\9m+_]A�ml�B�w����U렫�mY����i�9�tZ���R^!BZ��}}�����(R��Q"����M�?Э��,8C;������l���U#��H��횺�}{�f����&����I���G~�D^*���r�؎='͚�b���2���{n>{����tӹǾ�ј�,�����c���h�M^6��E�=� �.ϗ���.�f��a'��y>O5�H��̏3�/���{f򞨢d~ꖜB��(Q�3{ &@��%�Pl��!9���/�gfj�Rª��8��UsL�a�Pb�����d9JM���̳�eN#��=b>��+WU�H����W:��Mr�P�c-���~U����(�G̯�^&���-X*b^2�c4f"��N�4��Ӿ�v,i������}4���1z�K�����Jkڗ���Q�� L�)�<ʊ������F���=���s���-3���1��@�U�^�|e�(����͆���rB���./���*Ǽ�;K�i��{q��v�B$ ����P/؋b� �7�D�!䢷��ϣ�|2`}�HȊ��\�_��p�]�P�qz�9�� E��<��Z�'RWT')�wG��DmSf^Bsz��|�:Nr`G,,����Eb�?.�Y�L�3Eђ��tb��X��b��]�ŀ�i���/���,P$edn�UU� �/�W����S� ���q��K2�Q�g1��T��E��M��圾$�%7o������T�Av�g��ήL���ґ���0�U��b���R���V<�4�\�"��]!����m��U���B ��&d�����Қ�\L%�u:�8���D+tI2�4���9�/`�X��^��,��.1�M,k ���#t:5�a�{N���M��@�B0�R��Any�0)��ۦ���J� ��HC ����o�UxG���rf&���2Ÿ#�\�Iq� H�#�o@W�hQAך3�����"Q��7�� �k�yMH���p������ ����eE�����rU]��S;�g�B���f?�%f� 5�R�Iv i� �9/F�0�@��R"�� x S5b#��U�j�N���W`SQ4��/�����T��p��m�P���:-d$�% !�)?�Aϛe�R9���TR�`^��)Y��Qr•�� � Nr%��� m����! ����F�b�����!]Qf�"�h;�]G[Nlx���s�`��ǣ�3��xw��)����ZW^��(n���b�,x"d�@��9[�}��b��Os�p�@*�(���~e�4=�|,�Y"�KKN6;������؏P:i��D�0��|!~ �R�������Y�J�����9�I+9k�v5x ��a*r�8s�`�j>=� >#�O�O�s T����ˀ0uʕ(� 7�;+J ��e0�?UE�D�1)��� ���qYnSB�̗��4�r�s^v���Of"e�)qJI}sU��L��J�����"3�,���>���=q|EoC+F��p�`��Ea�7Xv\\��(�����Z2&KX�8,eDa�f���(醅/����� w�R�'�2�yl��eU��ј ��{��J�>��K!�X�hI_�eu�՗b�$e��IFbuY��V��l ��6e�:���zi����� ��:@q&��(&�(6)��Vmh���� cy%f�ǥ)K}�j�;K�W]�� �I/�i4F�XZ����FD�gT;:(}K'��̠�(�$��>Kq�Xav#�Е�� ʍ����<#��JT(l:m$�Y��>,90,`~PؗeO]|���@H�c�:o��R�r�N���!G��%Un$��N��O�p"� .�2���$�S E��I���z������G�|.{,�e���4)%}�6O�* �e ��%�Od�7�?�������@R��Qg�˽����Rc%�%�=ݚƑ���KSp��YL#�jzd#��9!��R��a������"��}�}O�j�����hX�}�#�z��`����{�n��Ş��q.�?̽�F�<�Kɿ��L�C��/����)}���v)�y8��8w�������s;�,��<� �'>�g���O<3��X> ��y�%}��3xX�"d��7�u����C�,�P���6�����}�?� �<�| l��� �y��۴�~$� nh�C�F�tF�A��~���xf�| t7>��*� ���ԅZ�%�a ^�`V��p����F�b�XF�����g�8����(���j =8(�����|�����%�Y��MƘ�KoL�:��6�s�1��Q���\ ���W'Y�l���Q�Ͷ�dG����ّ�,Aל���)i��eR[����6��l� ��g�� �5�j��U�vf���^2�U7���/�� �v�i������&�1v�w���n���%�?3� ��2J����3���X�F���f�4��xdyf�*_�a�jwm��n��o9�#M0�83��� m*�!��ם�V���z�����2��Z����@gZBǠ�`I��2�O#��e��& �'�f�Yl��+� �a��h�m3Z�~6���"���4U�e�5T���sڣ�+tx���a�C����1J��AC��>ƚz��ɚ5�*���� ���g��e�y�T��j��u{Ʋ��@n�dj��m�|����~�{JW��Й��&�12@�X������ �gl���G����O cn0u[�E�� 6�u�3s��'hm�nB�"F���n�����abw��֯��'l\�Z{�ԣ�����;�3xT����n K;6ư��7[�A�ϖUm�;*}���Hd�������#��>�ҩ�M=#�o[eSu>l�$����}s8��E�)o�jZ5�U ��~�yO<3��X�*��`v{�"�R�Ф��������TE86K}%Of��u\��J��*F��N��Fu2�O5c�G���/Y����� D����G����f��*� �a�p uc�8J����X'�;^Wӏ����R=�ӡ���ɵ�����O�bcj��}�%����W%�n[z�a��ە�'��~�l&y>�i�k9O�g7+%K���=�&�2�͘ee�Ӓm���i������M�[�4��#���Qjͻ��}�m<��S�����]ݸe���%� ��;����k#�hJ��G���vB���%�>PQo�lt��ge�����b�ռ2�M8����ĸ}Iz��HՉ��L7�U�]��0SV�=�ߏ��c��?4w��j��sN��QC���⩢g��.mh��?ԏ��F�-c{��� ��|�oN�< 8�(c�ĝ�MZѣ��|݆��*�L�v^���J{�B*�7!�D�� �A��JF�ez58w� F�f�s��7|(��<���za� � T3/�(��Ԍ�j�ku��������.�PW�K���;J�*�p�0�S��� ��+E� �z�>��5��z�Io�2��o�������<;ڌ��8�5ZĞv� �����®B�$���Y9t���g�aJ���4N��� �z�:N���ͤͪ�"����i�KۀŁ������3S�n���#g��,�N��A�����J�޵['G����P�;:�(�������-Lz'�o �0A���媣#�ƈh_ �Ѻ�2`�P G��  ��b �C�If�����2�N�&���u ��C�z��׸s�G�MK��� g1ȳ�Ĉ?]�EXw�x��HKԆ6B&g���x@)�����h���&����^�%�� 3#|2��)���Y7�|/^:h8+�sD�d���Q%fb �a����V��d�o�e�����(����m��#m�X3����+s��$�*�Xi�{6��v��zj����{��6�_�U�Ԛ�t�R��d �^ᳮ��DCO�����^�)���&�p"#��͢����<?�g��Z����Wn�ݵ�-:7���Kjν�����@��s@(�E ��S> v�k����*�f��*�О��)9�=�a� ���^Xf� ��'1)�_`��M��'QY7mm'�E�����8RQKgBg۱�t5���+7���;��r0Ae�trݼ\E#զG���QD')�{��KW��R�������׵\�T�Y*�~5�6��K�7���L����O#| .F��n0��P�M�(�nAmBfm�g~��^�� �q`زN����Lt���]�-��d��l�AL��m����nj�9�Γ����b�B}J��э���Β�٤-�*u+� c1רdԝ�{@nD��l&�t�'��uѨU#l%z�E� Ͳ�f�R��g���@�8֊��(6�+�0�`��~~�F��*��UԔp)i'F�����FѤs�Vnf��5a�e���u�ƞwƲ8I>�A��~��n0-�L#gd�q�ȧ k��(�a�D8Pqb���`fv`������ꄌ���7�}�ƕ�դ;�k�U�����t��[>����p���x��$���uw����H��Lq����j�*X����F���5�!�ܩ��B<C*�6Y �v�@�E mV�BCY `̚�%�N#�0�b%I�[F�-@��3.RV��&��@\4[�R�4+%6� �]�ɘl���ب�\��o �k�lj�qYu������քι�k� �:e� ��P��������YZ�1d���� �E���Ab�C��@z��z�x �=2�Ӻ �xdjlӁˬ�1 %(��7``��e]�x�� �|�kҰUW�s������9F�b`3�f��=I�v욥 �KՎ���`Z�6�i�Ґ���U��.��x�-g6뫠�� ��*D�#%*�^�jB��$266Lm� �b�s�Q�@\h%V�<f� Z6���>��@�do��Q��#\:�U^���O�Y���gfb�m��I�m�#�-s�nz�����׵���53๳C�`z)�me���z1BÝ7q��� �H\$ז �3���=��u�>�b�2��Ď�jk�`k%�Z��(W}��پ�D�v3���^h&*�ɱ�Wo�X<��iɘ��l��0�� ?��D�o�^7���bu쥪t��O&%��:�ؼ89� �$�5+t#��X?����h- �)z3Z�`ĭ3:l�t��f�i�Yh���A� ���oL�{Lup�= L�kvNn�5�5#��͞> ���5��v`<ܨH��Ħ���R�iO`�8���J�*�0�Q�Әɫ(B4������@ i�R�hk��bd7�����ڻI�X��s���N���Gƪs�d�M��FGo��G����� `�b*@�������%��ʠ+9��?gp�d���_:š禊�yω�gE[��Q�$���3���:ƺ���T��K�K� ��%���O����{�8�x^��tZ]B������cr��8�}p.ڠ%4C����!L�t�la�6T��O3���Ȏ4��G�ظ@cKx���C<��-�� t% l4��m��w45bH�� ig��߽��#C�z���kna��k���H���e'˒Ei����}8I���nPկ-#�[%���s�VK�N����:��������?�2F���!�T��R5a�_O o96���Nϊ��KN>��rv��7b=���!�.��<���Vo����,\�{ۆ�1�=~�JF�A��C�ކ��)Z<���ƞ�n���_���W��<�_�@:ݸFw��ʏo����z��@�w��>p_g�WҶE/��>�G��:�u�����&�m����y��xm�֑� M�[n�L�x7�H�U�[�=�;�ľ8k�7�e%�ہ�*q�F�L�?�@l�)n��;�O�g`.˜}[˝��8 ��t��}��K�r���}�K�W�KX�~2@6c�`�9���|��(%*D��}�1��Q>�_�-����֪�t�Pm�|ծ�Pr�q�1�L9�������=�i�/���*�n�^ꋕ�P��k��������S�a��|3VQh�{�J�{ o;�qz�+�O�(}S��.�<����UQd�Ro���@� FR�=�{�"_��w��9�U9�UQ?Rf�� �����"�L����F?��]i$�sޜ�[�k#�B����{Km9t�Ė &4� 6W��Ș��E{�%�8�'�C����`-� �tW4�FE���s]rWp u�QI*�w0�*��$��M2ɩ�]��Քm�F��s#ç�X�(_��j�=W�~�4�)��Z*O¶jH�N �h���lE���-aL���04@Ne9&�ƭȶ�:�1������3˨�O#��� ���ڨʲ؇jbp��Ƨ���۞���}��ǃž?��4T@ݶ�h�Z �\@����C��%���[C�]wa�=S ]� ]j��&4����8�Ju�J��F���@Z�{�g\����.dq����N!�X�[�� L(�"��+����"��J�i�����<*)� ����E�> �)��-��观d��g�c�����i����_U��}ϡ �NTϼ �|���i�X"tr�Ǒ$�����Ur������.�왩M�Qu�Ft���J'\��h��p�A�2��Kg+V����򠜼��:�l�`?�lR��KN��VJ��5'tC��C4XTj�o�=���y`��vI(�?�Pj�B�`BQc|�Q v��e�3>DtzPFR�S�T3�`E��z�}_���Ƃ�������v��Ap��t�)�A9�w��%�vr8�~��H�����Tɯ��>+[�r$�b�M��[�ad��G�um�@H~��Ҭ�6m��7���\8�h2 K��lnJ�U?гrA7� �]о �EdD����@h�;�?��X҂3�����%��5\�P����5��ߊg�f��t����CSzx*[IГ�𶃊R�8;5BH�vM�0�Ŋ�c/�h;�$��/7�����|~yӹ�=�,�T<Bj��z�� �+�%�t��#�S���th� �5 |�%� �UJaI7t��p9;�:� ���SZ�(n�Vl�j?��[Qd+�e�uh|@���!��P��%yG7����x� �.T�c�Px��r �'���-�rXӶ�_@ζ�]m�4���<3���׶6�H8���%g�;k��aO|F5Q@�B��L��� �r�lux���N(����L,$u0X1�a^�[�ZVh�"�^��tXқ\�©�F�.�1T[i�k����^e8� t��'(t2iaZ�,� |}���3���NK��`ZOo��:�h�y�K{��-� 5{���X@�Y�E�����k���;2��3V��jT*��9� ���yR��9S��?��&tK�λJ��!��5L +���8���"�3.�Q#*Ē��b�sJ p@�sy�g[�������?RPd�:�B~LJ�=�l��޹��ѸOty��ݓ�� J9� o��]w���3�3.�᜔b{2y<g��{�0 ��<��Q9!�7(���B�Pa�薂�P��D���[���q�w7�m�|L�K�<E%�&�X�[T�(�抔/�(8�Sw~�3-oO2I{ ���� F�F����"�e�NL �\��@���f��N�.l���춥 g,�ey�J鏸zd|έ|qB �ƭ8T��čQ��/�-E�u{����2�� �)�y�!i�3�\�!6�y��9��md�u�R�M�lK ������/y�w�Z�K;��Jƃ�����[Ά�`�����N8w�9X��� ��q�&� ����� dڪ���M���wb]ꇗ�c�.�O��-HrN���I��J�ynLJz-崑�O������Pj�f7���z����#x�zv�ߜ�}�Ƕ�����2��h��������Q<��ű���k�Q;9�9ǒ��z�'���˿l�׆b9�u6EI��3��@���y�������)��9�� ࿿�}�/�ؓ��E�i��ӽ���ql��/K�pҫ/�g�N�y��q ����O ��,�(���XV�%^�Ue�����&�,O~A�%��?����pCY�/P�����U��"��ߙ���\����9H��B,!(T ��i� ,�CT+���4���K���B� \����:%#"�A��p.�(����V�q�{)P*u��;�w��.�T~Z�^J �ktp�8$�aN��r@�BD �=�mr���J�FPmO�|�s����w��@7�R0`�C�B�+tx(�6���^� �# �h) `+)k�,�{���x&������ ��4G�0~Wϛ�h��8K]�,>��[T��$�S��h] �����\��8���Q��Y�YT�3��)���,�]���S�0` $E�*� ��%���S �ueԌ?bQT�À�e�$PMLv��@�򞮊$�L�c����"+� ��%���s �A��L{y�!�B�81Hl5n�zrX��n�|%�@�!���{�.\\|�� �CTN��nĜ��H���!����b���UT(tYTKtv�K��|`�Äka���u�fݧ2�{��y]�F�X0��� q�B�R�K��|�C���@���f���)�IMqbl���*� ��H�"F ���c�O9��..~��/\��\�p�s �0���s���K�����KNv���_�K���63���u;��%S���_B���/q˦� `6��v���6��/K�Mtf�/)l����F�`�A��/�B3x�Ot���@�9� 0"b�=�,���Y.m�����Ğ�ѫ�UL�Zw@�ǰ��W'Y{sG����1��$�8l���/�sC�a��{����&Q���F���67~��FPW.�$!���r���e�C�V�r`�<�Kԏ�!�,�4���]-l5�6��@��<�ye�cɏNx�/玱G�{]���6��x�| �}Ќ�����D����1�d�J��\f͘L+��:���3���ꏪ�r���ٶ!���J�ژ�h�qOQcDm�M��΁�l��^ؑA���>r��o�լݢ����^���”��9Ⱥ��Dn��"{��%L��� ��L�ٸ�^��0�%��A<ZkfM���n��EsOO޶C�A�'Zkk����79��U�&c��42?[ۖmUv�������N)�a�Vv� ���G#*?��k���JQ< ؙb r5�������7���E-n�a��������O���Љ���23= �f����7��~[f1�hJ�+`]���@{�jZ��w� ��G���Jo[}_Yk�^���!����w|�y}���>�ɬZ/�.�%oln��u�� �9�L�܌�����hZL�[ ���h*0�H��l�"�)(њY{ߘ�*1����� �m� V��4�4Ⱦ�O)C`�Sg�X8@�}�~0����w2�G�*��R2�j \S�9��{�R��8s E������F��:��VO�*��z��k�\��F��M 8�> ���Z�Ԯ����w�4�q�\썳�Xo2#�4��3 h̀Զ^EZ� ��Cw�B�� /�]���C� hE��*�%���@�b%�ΘP���$�h�@qN/���i��W�)��:�W� �b�IN��m�C�,������I�:��E[� �ei����-xtxm��I�HB��bƸɁDE]�!˲��'�PB�$J��"��Z�X�d{��MJy&f�X�r�c�$U���#��Ԕ�Ԅ�#��]\"���k��8��T%��Ep�����vq�`�+�N�@N׶�Iq��H���=*��hE�HL��f��H��udZJ��>�EGc+�L��$m֧H��d4�Hd�if�&t�x��v�/��0%N TЉ�o_��c�f��Y"���d���6=ME ������s�=�9�S�������2���`������:6�\d�6k<.sis� �3��y^LEǢ����q@3ak��4f�b���$�Sp��A����4���j)%�0�J���� T���Л���$��x� S$$��.5��uC�8m�2�iV�Ќ-�'�����#��M��i��@���gc�M)�YӔ��%�;e� y?M���΂�S����1���~j�2ޞOS�&��:c��67�{q�4x�~oǦ���ф�c�c],��&Ïu��L�d���c3T@`��O�5�KRM-�֟�w�o5B�f��'���W��>J!� <��OPNHx�<���V�%����gZ�6ٽ^���?�~��e��o{1�S~�Fɡ����ܫq<��&��/�?�=�����98u�k^�fmv7�:�=x�#'�����MÇZjq������,���`�u?�xJo0���O����;�����:�#����4:�����Y��������DQ�,��I�R�:��@A�r̷��K�~q�T��O�x���{�rJ��YOw.!��� ��O�h(X��QB���s�*z�IB�} O���W� _e�5ic��s�Z��yUHmx�� J����W�����SLדl�L5�@��sJ�� �wy0�i:S^���~�Pei&�V�%��\��@M��i�=z�cr�� �j���,uhC��1gfk�e�"��Rۖ���ӴC �ςo�"K�\�@��p�� ������Z���c�"� g>h�>��,���0���lI�L$ 0�o��!h�ҧ�RG� ��@�:��l�pJ��%Ւ�m�A���V�B��/��Y�o��Y�TZ6�D990Q��چaMWq�¾}@�u��`�h�g���$v����j�#��?���HU� J� V��:A0�pߒ(XChW0��d��9�D�<<>>�����?>>|�8 8��7���a���%SM˯Ɖ����&f\��:F��RE��I&�u�\�T�55�#s ���N!GT��;N���cy�'~���c���Q~�'��J)�R>0��*G�T}�&�/֘꘸�}<sj��'��|^JN�-�P�c&ȟ��`9�ϔjȅ���|}d������xf�)/j�R'��p��W9V�e�� h�8�� x-#�ְh�K-vi��8�`&)X��c%���d�P�I�B?�&�$.����w}��#�Cb���1�X�[�c9����}�cJ�ʗ��9� �Wt���#�e0R*�fJ ��0 �(鰉� �[��J�R�e��!�f���'1�X�d?|��ǿ���@�o�%$F�FT�u�e�&�w� 皘\Ԋ]b#��.��cL`�u�Æ2f�k��ů�N¹�:9!Z�ώ������Y�Ы*�{�g<D�~������<�����~/�KJ9�}�>�R��>KCcR�*3X�ݪ^�pl�������V�`ܝ�k?6 �nMm����|^���b^.��H�����o �������/����=�O��ϣԱ�Ը�#����1������w�w���ijU�V���i&����#�ý�_�u���ך��jͯ)T��H���8�ē̱�Y���_n��×���Ou�A�� � r�w���ɏ�^���b�T�*���Ju'>�@��c/�M�G�͐��~�������|y��c ^ ���*��l,��z�f���-�������d�=�Aē\(�m);�w�E��/[��������� ^��1W�}��8��%f@(|;�OO0�}�X �ٝ$`k%�b�݌�R����: ?�� ��T-����]D��9,��k�g_��'B�a�����.~w�BϏs��\8�SBxk�X+!w&&�=!��CBH��D�n�w+�4���‰�z�M9���Vg%-�4:7iBx/�5>[�D&I,��81HB(�ٖfN$��B�?�� ��ORǾ�4��-cNvI�\E^�c��Ǫ���WQr�~�1v��|+��=%��%A^���ѿ�v�K#���� �%D� �^a 02�I�XJ� eNJ�|w;�VUI��R��b�q4�V@` ���R��!zR#ъ�'�YH��g,#�2��̍@'�Yq�M�����t� �lZc9�� Z���֚���'�ؿ�4E%��� �g}X�q՝�hk����x��_��믌6��̊�:e����yuO02�F��q��/�b�T[��*(���1CKƖ({U��Mk�O���)�׊��V��uv��Η��?p�9{Q.����["�R��QGR�}~��[�s �sq�=���M��A���:�5��b��s�J�,$֨�(X: ��k[QBd�&�H���C��P�y�=5@b�Dn�~A����@R���tU�ɟ� �4�1�iw�+� ���)�I�(��U�J�TE��N����VlH�����V�����!<��S�[25�w!jY1�gc�Z�>�15�:��������%@���I�H\(�Y�ӂ68�5z{T� �r�8���&5)��8��n����X�E!���󼰋Hsӈ�Ce�Q�<1�/li����o��D��s�5Ԋ���;��.?`��eXL��d0;��I�6'��� �5'�o�c,߯TF1�����~���_)�[��w!虋��@� ���/ n# �n%����Z��]M}f��o�8��M������9/g ��m���>���[�M�!��UYv�;�y�pz^!�ֵ�q�埭˗i�K��+�4��Z �՜wBk! �x�9OD�q�#e�I�P�-{o���S�m���,��C��\h_�j�DڞC$�ĕ��Fҩ�0O����8�� �e��NBP��H�.���ආ ����U��[����tL��'��L-i��K��@��O܅�d����Lc;���!��%$q����jd�m$�~�*UB�TAÞ'����j�v���d�2���N��� �.4X�,�B�$: |Q��Q�Xٕ�r��T�a �or�����7��B��_0���Z�I�ҙ6ĵS%9$�]�u�k ����A��cO�Ug�u�D�`�!��S�� m����c,�Y�E�eű3��@�ސX����k�ب��ح��=� ����TxSҷzƚ$�C{�� �d�s!�Vz ��B�J�pJ��]�U{0a5б�Rb��s�H�øP9��i+��V_ZO}}�`b�ȶm��Ķ�b�B�0���X&�_G�l|J�`��?f����[{T0����/OP�D��; Z�M�M�]����+�Z�J��d� �|�i��fǦ�z�M�i��1 �P�n�K�l�${�$ �M]"�O�� �yV�nO�$q�ʘZc��%�� ��>������Q��n��*5�5>���l�D�@��R� ��B���E����*��0���C�S �N ���V���Y��9���|�������B������0z�VD%5F�M̶�CSގ; ���)M��h�� �f�0����M >��Z�[�� ���7�ǽ���D$�R���+�V��+b��O�m�"���q �q.=8�����y�87^��* D Z; ɸ��rs�HP��Z��7�Q�}5c��d���qFJ�NR����&Z�o �L�o;��$�~�:O� �w�y"����d�zB��H�������O�@���iB}���,E���Pف�ǭ��� �`*i��e��I�vkb��>�[�yf��/xЊ��n-�b�|15=��ӱ�9��/膁ֻ'&����1�@���)HS����yv@ڒB<FW���㠅��)�ԝn9~]Վi�P��� �6A�aw;���`%t�����0um�oV|mV�[1�~�����ة���8ٔ����� �d��W�� ����c6�z e���ǀ��iq�~}9Ɍb�A�W��@ aP�g#� H�gE t����k�� �����LF��g����3B2��]LIKS6"��+OR/f�)���Pb�l�`�"�b�Ȩ.�&��Yd� � ��7��|W� �[�$�F~�>��7ʬ��Hӎ�:����Y8�%E(/�^�w���PN�l7̘� _U~<_�I������3�O�<�8M@�(̂�o�h�Be�9�%4('(_��c@ψb������F�*H4��@��n~�d?*���\ t'B\��ۥ�W�׬�.T�5���e��o"� g]�C�#��b��Qm+/XL������o}���ջ�$�yC�Z�w������4�R^!*�uy��ܯ�ݴ�c8FS�T�ɮ�)4E���cd�u��9(����Q��mss�<�Ro�86�}�Z��Mg5���C�������KB�Y��L�R�̜Z����@۱�E�<�x��$���K��%�H�:BunX�k��(cQ9})(}Ŧ�,;�t�r�w�����{�q���3� ��-�C��]U��2̭Qk|���`�� $�2��H"#�{_���OץtT�g��LCc������P��lF>�VŲ�m#nvP/ �"����v�����}3��}]�b)]���Rx[�8��Jm�%���-�i�7o0�۾���w�E�&Z~��A^$���B��cV¾��x<V磂Ͻn���dc;Jeir�Ρ <ق�h!�識K��ء2��ʯ��7��5���α]BS�T�������@��Ul�b ���� ���J��rܷ�[��vۃڐk|+h��*bS��l�d۝�d��虎�_��g��������/��%yO�V$����>oc��5��q���DBX!��:}"3���8\��]����d��hi+ލ�+���aJk��~�����0��Dx{�Y�n�I#��CK�I�Ab��� �^�����X�%;I�K�}� D}�x��!��Y� ���+�c�ϘG�L�Q9 !�ҖBTvs=�x���z����rm��Fh���*|�������/�����[��×o��J��wo �\�l�4�u|�!�����:}Z��I7{����<5c�C����]Lq&���FD�!�n��1�)国HH-z"̘xo�5��a&� [3�?_��D�A���� �+�ނ���?�y��כ�/�������|<�I�}O�|q 2|!y| f�Ȃw���iѰ:f4��Q�{,T�u�~��"�Ǵ�6:c����$ά0K���h4�MO31&z3����(Wk;Y-�㙘���{�l�(�M#��̲[Ƹ3�� [�k_�?_kEó+ �}{��(gL����� �^��إ�<����l���`2��g| �;`���*�3�\��Ik�XAɱN?ej&aQ`��p�O�� ��|2��E�G��LT����Lt�Kp4%�{N3���Dk_!5s��&�I9)a5��X�Y���}�jxv���;�vQ���������u<&� D�C���/v~��Ydf�� �����C(ygP������P� ����7h��G�����S�j����?@TF�vf�D�1���:��"9<{ӆqBF3��a#=� �,��:�� T�–w�3y0��|�����~Ǯo�x�����5 ��)bP���c�pI����[�^><�� ȕ*9H�X�`�� %�X�D���^��� �֤Q_1� f��#�sǿ�"B�k�GITײ��ws u����W�NSc��b A�(U4�����'ο߁����v ��h@@`�G���`V �w��SS^�w;&V93V$�cNn8�鷊�Sڧ����o��1taJMunFJ�6�jr`S"K3���\�z{�uf�0Л!��8Ɖ���m�1���!��b4���K�B�9�<�$w̵�O� :���0`����u� ۔��L- +�{��X��[��t�v������@k�m c�U�E������7m�sc+���(̒���OcM�y��H�uj�����.�P�Y?����{ �$��#`���Ͽ0s��|ͅs���@�S��ؖ������:}�'����P�����~|͚��"@�a���� �����ۆzw���Le��S95��� :��3���'zJh�Lq���'\%�烺��ߎ?)�pD����|����Հ��&�u�XNw;�We�9�sr�����@���@�f9����;n�P�����O��;`�/�����)i����.�ȇm��?���t�W� ��m�6���x�ϯ�E�����Bt�>���� (^�������� ~��`J)7���o�@O6���O�c��O�]<�>����M�����}@���"^}����Gs}�{��w ��;E�����y�S� ����Dל<�$�Qu5&y&t /��&Q��o�8���V��o�@G�����Iexl��/�˓�"ީ�} ������6ѱ_�H�$��g�cI~���{�rJ�� ���h'$���УA�/U�J)qk�n[3_�������<T�9t�,zh$�H�DE1`6lT >+ M�(�V�ۙb�u�*�. E\��ґzg_ �5�kq_�!*�8Ԧ�h,��˶�q�7�����Q<�&�`,���������h���9-�l�X���C��*�+*��l�TE*���<RJߞ�:�S�C�@d�Œ1T��E 5f �bM�T��>�E�\H�[kr5���0[�i<Y�Y���'��<�������cLc�(��:l���֚T��Հ�m��ۦ��9TY�ɫ�{kI�1��*N�Te��>��2����iD�� S��Ksl!.�t�����c�K� ��$�!�{��e�R�="%c��J����2)g�������ԙb�| >�^ �ǭ�d3i=.q-ʸ����dm��f1��5���7.:�8�����tv���ҮtJi=u�3-Zu����KN+S�u���Vq�̲2=�$Y ]�\m�� �'��ŮJ�m7�]�oϩ�V��gRX�d��n��9Ib�d�9Y0����c��` {���_@�\tˠ!�^:����%زc��!J��e�ѭN�l�d�V�y�����������Ŝ؎���j���]R�$�������@Yh�cGU;� "�MG*}�`+3����fF��l�ה6%)�����q����KOH_�� Yf�F�,X*-�i����kzmð��8v�۾�2�֒TLt�7�aL�2����&���9S(U�V��ӄ�6eN^@��G���͝�i�=1U�ߞ�=q�s�+���Km� k�!����[uO��!�&��#S�umc{��UQ=� ��L���a�^ _ME�l�$olQ!�F(9 ��=ʤh i ]�,�����z�XJ6�A Z2մ�j��k��jb�\䝖�c���6�:��҆ߴ���\@���� �4� x~��N����I��aZ��,�IWG��� x�('�2�����s�����K�@�ж�/���8��)f[A<� �HL��4ʡ�!@�(�Zv{0'������ r�(��e������Э�9����R��|`��1T�����I��}d;&���4*�c90>ق\���`�`��B����M�����1%b�o�/�m Pc�������M�R�>������o�lY)��s�綼`����M3���>�&����L�(S���`h�Җ�"z���4g��Ӹ�e�S;�3�ܘ���4���pn��3���d��K���q�`�XE��93�"��{~ʘj�虈cIP�>=��_#�=>s�&3sZJ����ErBK�ƣ*��� :�J!ZB���J&�F�f�o�BƬ�)F��@-k�>h?�:���C~��;$�$2��,DZ�I���nY��Q�@�c]��lj��c6k<$��1�J��c:���<�ǡ��-�M�a�Ўe��RR���}�����hgJ�;tL1��}OˡwN�<�bt�)M*_zs��l�����W$�9������Ui8O�7k���KA �J�r3�B�pU���Z��i���c�.3�)��DI�go�ibBBΔsQ�{P��z��qL��O�S�L�%�w��@P��R*rJ��b��;jr���8�{������Ĉو��ι����N�@"�\��Z�(�k�p'�H�X ��nO��$��{7�ē-�2_7<�B�ф��2JU�g�~D{)+��x>.�3 �� QP�s�\M�5+~�u��qw��������s35f�_�fD��%���'��� |��g� p��c� ٝu��!86[��x8l�-���?�e�O��p2h�[C4XAR���|�����!�'��U�'�g�I���{INc � b��B?������>��ԩ�N�:p�ԩ�N�:p�ԩ�N�:p�ԩ�N�z#=�:u�����S�N}Z�8u����S�X'N���:p��'� �S�>�N�:��u�ԩO��N}b�8u����S�X'N���:p��'� �S�>�N�:��u�ԩO��N}b�8u������U.9Q�IEND�B`�
248.422907
1,098
0.262178
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
AWSTemplateFormatVersion: '2010-09-09' Description: Airflow server backed by Postgres RDS Parameters: KeyName: Description: Name of an existing EC2 KeyPair to enable SSH access into the Airflow web server Type: AWS::EC2::KeyPair::KeyName ConstraintDescription: Must be the name of an existing EC2 KeyPair S3BucketName: Description: REQUIRED - A new S3 Bucket name. This bucket will be used to read and write the Movielens dataset. Type: String AllowedPattern: '.+' DBPassword: Default: airflowpassword NoEcho: 'true' Description: Airflow database admin account password Type: String MinLength: '8' MaxLength: '41' AllowedPattern: '[a-zA-Z0-9]*' ConstraintDescription: Must contain only alphanumeric characters # Mapping to find the Amazon Linux AMI in each region. Mappings: RegionMap: us-east-1: AMI: ami-97785bed us-east-2: AMI: ami-f63b1193 us-west-1: AMI: ami-824c4ee2 us-west-2: AMI: ami-f2d3638a ca-central-1: AMI: ami-a954d1cd eu-west-1: AMI: ami-d834aba1 eu-west-2: AMI: ami-403e2524 eu-west-3: AMI: ami-8ee056f3 eu-central-1: AMI: ami-5652ce39 sa-east-1: AMI: ami-84175ae8 ap-south-1: AMI: ami-531a4c3c ap-southeast-1: AMI: ami-68097514 ap-southeast-2: AMI: ami-942dd1f6 ap-northeast-1: AMI: ami-ceafcba8 ap-northeast-2: AMI: ami-863090e8 Resources: EC2Instance: Type: AWS::EC2::Instance Properties: KeyName: !Ref 'KeyName' SecurityGroups: [!Ref 'AirflowEC2SecurityGroup'] InstanceType: 'm4.xlarge' IamInstanceProfile: Ref: EC2InstanceProfile Tags: - Key: Name Value: Airflow ImageId: !FindInMap - RegionMap - !Ref 'AWS::Region' - AMI UserData: Fn::Base64: !Sub | #!/bin/bash set -x exec > >(tee /var/log/user-data.log|logger -t user-data ) 2>&1 # Get the latest CloudFormation package echo "Installing aws-cfn" yum install -y aws-cfn-bootstrap # Start cfn-init /opt/aws/bin/cfn-init -v -c install --stack ${AWS::StackId} --resource EC2Instance --region ${AWS::Region} # Download and unzip the Movielens dataset wget http://files.grouplens.org/datasets/movielens/ml-latest.zip && unzip ml-latest.zip # Upload the movielens dataset files to the S3 bucket aws s3 cp ml-latest s3://${S3BucketName} --recursive # Install git sudo yum install -y git # Clone the git repository git clone https://github.com/aws-samples/aws-concurrent-data-orchestration-pipeline-emr-livy.git sudo pip install boto3 # Install airflow using pip echo "Install Apache Airflow" sudo SLUGIFY_USES_TEXT_UNIDECODE=yes pip install -U apache-airflow # Encrypt connection passwords in metadata db sudo pip install apache-airflow[crypto] # Postgres operators and hook, support as an Airflow backend sudo pip install apache-airflow[postgres] sudo -H pip install six==1.10.0 sudo pip install --upgrade six sudo pip install markupsafe sudo pip install --upgrade MarkupSafe echo 'export PATH=/usr/local/bin:$PATH' >> /root/.bash_profile source /root/.bash_profile # Initialize Airflow airflow initdb # Update the RDS connection in the Airflow Config file sed -i '/sql_alchemy_conn/s/^/#/g' ~/airflow/airflow.cfg sed -i '/sql_alchemy_conn/ a sql_alchemy_conn = postgresql://airflow:${DBPassword}@${DBInstance.Endpoint.Address}:${DBInstance.Endpoint.Port}/airflowdb' ~/airflow/airflow.cfg # Update the type of executor in the Airflow Config file sed -i '/executor = SequentialExecutor/s/^/#/g' ~/airflow/airflow.cfg sed -i '/executor = SequentialExecutor/ a executor = LocalExecutor' ~/airflow/airflow.cfg airflow initdb # Move all the files to the ~/airflow directory. The Airflow config file is setup to hold all the DAG related files in the ~/airflow/ folder. mv aws-concurrent-data-orchestration-pipeline-emr-livy/* ~/airflow/ # Delete the higher-level git repository directory rm -rf aws-concurrent-data-orchestration-pipeline-emr-livy # Replace the name of the S3 bucket in each of the .scala files. CHANGE THE HIGHLIGHTED PORTION BELOW TO THE NAME OF THE S3 BUCKET YOU CREATED IN STEP 1. The below command replaces the instance of the string ‘<s3-bucket>’ in each of the scripts to the name of the actual bucket. sed -i 's/<s3-bucket>/${S3BucketName}/g' /root/airflow/dags/transform/* # Run Airflow webserver airflow webserver Metadata: AWS::CloudFormation::Init: configSets: install: - gcc gcc: packages: yum: gcc: [] DependsOn: - DBInstance - AirflowEC2SecurityGroup DBInstance: Type: AWS::RDS::DBInstance DeletionPolicy: Delete Properties: DBName: airflowdb Engine: postgres MasterUsername: airflow MasterUserPassword: !Ref 'DBPassword' DBInstanceClass: db.t2.small AllocatedStorage: 5 DBSecurityGroups: - Ref: DBSecurityGroup AirflowEC2SecurityGroup: Type: AWS::EC2::SecurityGroup Properties: GroupName: AirflowEC2SG GroupDescription: Enable HTTP access via port 80 + SSH access SecurityGroupIngress: - IpProtocol: tcp FromPort: 80 ToPort: 80 CidrIp: 0.0.0.0/0 - IpProtocol: tcp FromPort: 8080 ToPort: 8080 CidrIp: 0.0.0.0/0 - IpProtocol: tcp FromPort: 22 ToPort: 22 CidrIp: 0.0.0.0/0 AirflowEMRMasterEC2SecurityGroup: Type: AWS::EC2::SecurityGroup Properties: GroupName: AirflowEMRMasterSG GroupDescription: Airflow EMR Master SG DependsOn: - AirflowEC2SecurityGroup AirflowEMRMasterInboundRule: Type: AWS::EC2::SecurityGroupIngress Properties: IpProtocol: tcp FromPort: '8998' ToPort: '8998' SourceSecurityGroupName: !Ref 'AirflowEC2SecurityGroup' GroupName: !Ref 'AirflowEMRMasterEC2SecurityGroup' AirflowEMRSlaveEC2SecurityGroup: Type: AWS::EC2::SecurityGroup Properties: GroupName: AirflowEMRSlaveSG GroupDescription: Airflow EMR Slave SG DBSecurityGroup: Type: AWS::RDS::DBSecurityGroup Properties: GroupDescription: Frontend Access DBSecurityGroupIngress: EC2SecurityGroupName: Ref: AirflowEC2SecurityGroup EC2Role: Type: AWS::IAM::Role Properties: RoleName: AirflowInstanceRole AssumeRolePolicyDocument: Version: "2012-10-17" Statement: - Effect: "Allow" Principal: Service: - "ec2.amazonaws.com" Action: - "sts:AssumeRole" ManagedPolicyArns: - arn:aws:iam::aws:policy/AmazonS3FullAccess - arn:aws:iam::aws:policy/AmazonElasticMapReduceFullAccess EC2InstanceProfile: Type: AWS::IAM::InstanceProfile Properties: InstanceProfileName: AirflowInstanceProfile Roles: - Ref: EC2Role EmrRole: Type: AWS::IAM::Role Properties: RoleName: EmrRole AssumeRolePolicyDocument: Version: "2012-10-17" Statement: - Effect: "Allow" Principal: Service: - "elasticmapreduce.amazonaws.com" - "s3.amazonaws.com" Action: - "sts:AssumeRole" ManagedPolicyArns: - arn:aws:iam::aws:policy/AmazonS3FullAccess - arn:aws:iam::aws:policy/AmazonElasticMapReduceFullAccess EmrEc2Role: Type: AWS::IAM::Role Properties: RoleName: EmrEc2Role AssumeRolePolicyDocument: Version: "2012-10-17" Statement: - Effect: "Allow" Principal: Service: - "ec2.amazonaws.com" Action: - "sts:AssumeRole" ManagedPolicyArns: - arn:aws:iam::aws:policy/service-role/AmazonElasticMapReduceforEC2Role - arn:aws:iam::aws:policy/AmazonS3FullAccess EmrEc2InstanceProfile: Type: AWS::IAM::InstanceProfile Properties: InstanceProfileName: EmrEc2InstanceProfile Roles: - Ref: EmrEc2Role S3Bucket: Type: AWS::S3::Bucket DeletionPolicy: Retain Properties: AccessControl: BucketOwnerFullControl BucketName: !Ref 'S3BucketName' Outputs: AirflowEC2PublicDNSName: Description: Public DNS Name of the Airflow EC2 instance Value: !Join ["", ["http://", !GetAtt EC2Instance.PublicDnsName, ":8080"]]
32.689139
287
0.63131
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
0
0
0
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
## Data Orchestration Pipeline Using Amazon EMR and Apache Livy ## Setting up Airflow using AWS CloudFormation script ![Airflow_Livy_Architecture](https://github.com/san089/Data_Engineering_Projects/blob/master/airflow_livy.png) Script is available publically and can be imported from - https://s3.amazonaws.com/aws-bigdata-blog/artifacts/airflow.livy.emr/airflow.yaml **This requires access to an Amazon EC2 key pair in the AWS Region you’re launching your CloudFormation stack. Please make sure to create a key-pair in the AWS Region first. Follow : [create-your-key-pair](https://docs.aws.amazon.com/AWSEC2/latest/UserGuide/ec2-key-pairs.html#having-ec2-create-your-key-pair)** Steps to import: 1. Go to AWS Console -> Search for CloudFormation Service and open it. 2. Click on create stack -> Select **Template is Ready** 3. In the Amazon S3 URL paste the URL mentioned above. 4. This will load a template from `airflow.yaml` 5. Click Next -> Specify DBPassword and KeyName(the already existing key-pair) and S3BucketName (bucket should not be exisiting, it will automatically create a new bucket). 6. Click Next -> Next to run the stack. After the stack run is successfully completed, got to EC2 and you will see a new instance launched. Connect to instance using ssh connection. You can use putty or can connect using command line using ssh. [Connect to EC2 using putty](https://docs.aws.amazon.com/AWSEC2/latest/UserGuide/putty.html) **Connect using ssh from command line** chmod 400 airflow_key_pair.pem ssh -i "airflow_key_pair.pem" ec2-user@ec2-your-public-ip.your-region.compute.amazonaws.com After you are logged in: Run Command: # sudo as the root user sudo su export AIRFLOW_HOME=~/airflow # Navigate to the airflow directory which was created by the cloudformation template – Look at the user-data section. cd ~/airflow source ~/.bash_profile #### Airflow initialization and running webserver # initialise the SqlLite database, # below command will pick changes from airflow.cfg airflow initdb Open two new terminals. One to start the web server (you can set the port as well) and the other for a scheduler # Run the webserver on the custom port you can specify # MAKE SURE THIS PORT IS SPECIFIED IN YOUR SECURITY GROUP FOR INBOUND TRAFFIC. READ BELOW ARTICLE FOR MORE DETAILS. airflow webserver --port=<your port number> # RUN THE SCHEDULER airflow scheduler [Authorizing Access To An Instance](https://docs.aws.amazon.com/AWSEC2/latest/WindowsGuide/authorizing-access-to-an-instance.html) #### Once the scheduler is running you can access airflow UI using your brower. To see the Airflow webserver, open any browser and type in the <EC2-public-dns-name>:<your-port-number> REFERENCES: [Build-a-concurrent-data-orchestration-pipeline-using-amazon-emr-and-apache-livy](https://aws.amazon.com/blogs/big-data/build-a-concurrent-data-orchestration-pipeline-using-amazon-emr-and-apache-livy/) [Airflow Installation Steps](https://limitlessdatascience.wordpress.com/2019/10/01/apache-airflow-installation-steps/)
44.652174
312
0.758654
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
�PNG  IHDR�6@�\sRGB���gAMA�� �a pHYs%%IR$���IDATx^���dř��ߢ�P(���O�V�J�X@ ��E-b%�� �f� �`#��=�A���a�{� ޳���ʮ�����T��ꮞ���;��T�<�yҝ���6[�tu�$I�$I�$I�$I�$I���LiI�$I�$I�$I�$I�$iܴٞ����_tb_�2�'I�$I�$I�$I�$I��)+�v�K]5���M�dJK�$I�$I�$I�$I�$U+�x�C]1�� M�dJK�$I�$I�$I�$I�$�W���R�6�����dJK�$I�$I�$I�$I�$u�� �j��Q��]�4��2�$I�$I�$I�$I�$I���s�L��4�0���NF�֔.�C�$I�$I�$I�$I�$�ۊ��ɤ(Ou�M�(�ɮNL�P$I�$I�$I�$I�$I��K�g9�婕6�"��Δ� C�$I�$I�$I�$I�$i"y��IQ�J��)%�Z�dUV��$I�$I�$I�$I�$I�Ƭț���)J�%SZ�$I�$I�$I�$I�$�� ꞙ�Q���_�.�~j���7�_q���:���`��,���u*�Ғ$I�$I�$I�$I�$I�y�㭮��Q�0�~���?J_~�eS�~�Yzf��t��g7 �/��"�7���a\u5ަ4F�ǟ|��z��l�GaƢ9�A�<�̋�c+V�M�����;|bXXI�$I�$I�$I�$I����<�^�cS:Jt+a8�2oA�l.���֤��V6ì^�>�}��a|u�+S:*T��Q�����y��3�džL�'����)�ݖ?(X���tĩ �H��Y��9������@y[=��?������|����^Y{�����}/=��3i�#O ��Tt�yW�Ys� +_>�Z�tE.��t���u��J�;P���_^s< o퐿��uĽ��7p�I+z����}��- �J�u�#O�6��矏�?�$I�$I�$I�$�����ɤ(O�R-S:JT;���'�7�5�7f�]�V�~��y��i]��-X�|�� CuӔ�ʤ�d4��zvf66�� ��)ʐ��L[���.L��f��f'��{���W��^x)=���t����g�gqoKs������rͺ�t���}�ɷ �>��a��JQ]�H�_lx�ݜ&�Y�>��ʆ���ᧆ�C9�a���ǟ|����v��k��Ks獸c5��oN�C:���o�>���5���K�y��C��Z������ҵ����$I�$I�$I�$i�y��IQ�Ƣ��t��:z��g���b� �[�O4���1����{���˰0�U7L�L�4�LiVF��c�+n �L�6S����_�W�F�8�����^���ի�r���Ӈ}� �G�=7��^��Li>�"=�V�VƔ��_�e�a{ɵ�6ߣ�9N��Uַ��Xe��Ք��Gҧ�}���ֻ��1��39����vN$�h銜L��n�3 'I�$I�$I�$IR)� '��<�F��ttѺb%(�� �+�U?\�1���`�X��Ք�ʤ�&�)}�=�d C/z��1���ܟ^�;b�m)3�Y�˷ �x;S?uS6z���'S�� �\�ˈr���|3�c����VF>�y������)=������.�3s���|��=�N˫�� ����$I�$I�$I�$I�S�EN&Ey�T#L��But��d�������9Mc���G�q� ڶ�@�M{> ׉�Li���M�?�a�a�bnyc����N�_x��b��r�Ȕ��X�AiqP.|m?Z��W��/^�ϣ�0)1�^��8��Li�aHھ��3c��9�>n/L5� �Mz����E�'�V����6����JS�𤉴�5I���Όz_X5k�3<�̋���i�\��>ϝ�U����u�붼� ��Q�Ey��z��a�/���ҫ���!,y+���|�$nV���H�}��WG�����s�rڹ�7��4����{�2�z�?>�y܋{͇]v� G��p��x}]Bc5���Ei�/ˠJ���)�9�/I�$I�$I�$I���&'��<�Q6��;+;��6�hoLcz��m=�sM��JXL�(L'�2�m�di�"3�l#{�b*b�z���Ũ� #vn+S��)��ň3��� ���i#,_�7�㥩gqG�Yy�е2(������#����}��j�OMa~L��~���&==���3�/� �C� D����}1Sy#�� yB��ѿ=�߿�'�v �e��D�)+�Q����8��������CQc�u� ��`�z����~K�:�4+�I��I�\��M{~V�?�f�����uryf#} ��#d����^��mMX n^�w<��4����1�I�O�����vK��(����o,Z�o"-��,��XMi��}�Lik�o�nMgL�6��%�������z�Ze I�$I�$I�$IR���3'���Ti�(�Nt��4 - #�U�7Q6�[�{��� ��u�� �ԕ���{�5yo,��Ho$b�`���pi:���/;�ko�'}�����>JS�|[>v�uS�G��~����cw<�d������o�{ ����?�ʴtŚ���L���J�>�||�+����������������gf4�nK�e��8���S��?���t�����i/��������;M/+\���/8�x�_�8��5�y��澾(�+��)Cʒ�P�>��%��_�%y���r�#�r��y����u<�fx �_��Ys^�Ǯ���lf����W�� kuᣏ?����c'�syZ����z�t��6�>2���6ޛ���4k�����kY�;z*����ϯ-�e9�|Z��:p�O7�ռ�w �ga�;a)��k�l���Ǧ�����v��󮇟��{�����_���|]D�������q�5���Vߐ�i�@Z��Z�֮�qqλ��ϳ�Y����=R��U��[ �+/�����4�l� ��x]�wI�$I�$I�$I��@ r�)��(�˫#S:������5c�U����ҬDeu ��Я���S��S�����!�����eE��@�H�E�P2��͟���|�E��Ҽ����~dڈ�f����cd����c���|�V�f����^��'�/]���MiD|O=;+�v�ʔ&,i��/V&�)� RV���?;�_4�\/˯�7��*��F�Ҕ'f�S��4V���k~:���΃t�}󭦙jqΘ=��s1I�-�e9��.�f����?`���z��8�Q���7a�b2s]��1+�Ҕ����z.=6��azDu�Y\�����=~��Ɗq���{R� w����_���g�ۖ�ڱHQ���V���W��kn��y���n����W�^7,�����?�A �<3����&i/I�$I�$I�$IR���,�]�_<Z�5��x����[ `&�X]�9���-�m'��Șfu����������)�vl � UV.b���^31�Z�L6 _ה6����>ϫb[���̰��3�ˌ��ڬ��0� �Ѥ�L�2<f"����71�Hqa���82�LiK�/g��L,�Qx+�V��0hY�ͱO>�,-Z�2���^�F��W�ǬRo��[֫2]^�)Ʊ�AP�fl���v �jV+s ����x��a�WT-���2uR�\_��<��R�Ӕ��g����zE��[%��ʼ�9M�7�`՚7s~h[�ڟ��O�AK�N�{�$I�$I�$I�$M^f?*�;QhJG�ľ��B��r1Dx�0�Y1m�1�1�y���jŐf�L;Te�u���WeE�x%�K���(de�߂�L6V���x��U��z�c9����������Sz�<�/wŪ�?\��w,�.:�k�� ��Ez��@���>,����9�����y��a�Q7��1�#�� �/w>���\�����'��gf��c�U�[W�^�[�I�tZ��Eto�+�4�i�� ��a�t�'������{�Ӏ��\��#{�u�5�=6���-��z�y��k��^s�ȳO��Ǵ�Q�z���ľ��u��/���5�F�ηt��l����k��>���k�@�r[u畢~�]�[�:?c�k9-y�|q�y'����l�|�ׇ�D��_~�Y֤���l�Os�X�g��j{�+�P���$I�$I�$I�$I��d_)Jo���:j��Q����J~,� i~��la`�4��_��f������Վ|��s/�Uʘ�+� �ڙҶb�� �~���ց|��Ə���.�"��̣��5�Sr�}�e�Ӳ4.M��zC c�_ۮɏ ڏzu��v�3�Ç9 a��1�0r1�����x���v��|�M|9{�e���)i��눸091�I;ye����4X^�4`v���Ϸ�G�G����_[���1e@�~���}3[}]�:��ңӞO��z'�[��a�%��V���I��z��U�C!L�^���W���ϯ)[>�j��Y�>�}�n�8[�7ӕa{��U�>hw�%I�$I�$I�$I�~e�)Jw yӹ�6�"�#V b��5r�0������� fJ{n���Ҩ�)Mz0�� Ԇ��g�3S�<^���4s-2y11c���|Ä�Z�����+mM��F"^�?����š��^�����/K��di�I� j{�[��&���I����+eK�3�/&V�s[��&L~�ϲ��8��i���9[�J~X�jƲ�L+b��Q�8Fy���_�k%[ ��h)��S���ɧ����~(��Ũ���{��܂���v<��c����EW����Aex�={�T��r��f$[��ʸ���x�V�3ˇ��-�����p�J��F�c���+I�$I�$I�$I�$Q�a����V(2�KunJ7�ь���|��4<�*�i~�k���{�.^���:aX��t��Z�deV�� 3��-�ʬ���w�� �N�4�s�iy��� ���c� �����H�X�&��1�~eoW~T���o�o�S. ����q��ٯ�2ys�;��K�o��\� �����KW�i��|���L��1?��1��h��?��tMc��R��w� /�����a8F���?��~��YͰ��'�I|��z���Cv� )�A�y���6i -�z�P�Ll��辘.��ּ�0�d��� ��_r�މ =��ѧ����1�I6�������O���y� \�ƏK^}�ݹ��W�8X����������ҏ��c���%^�"����vK>�5f�2/,�?����M��؞Ȗ?�h꯿W&�׬�0,.~���W������+�p���/�~d�f���1�ǩ��E޻��dž��k���Y��돏E�O} ����9Ӟi�{�zz"+��q�"<y�۷4�[�8��I�$I�$I�$I�&H�k�pE����[h��tpq3�׮;��7�i�4�e�R��Y�#=��0����cUS�V�r�������X̳Uk�����A6�0Y�0keJS Ñ���0�0'���0sy��?ͦ�&qp�4�8��#Qx������ď�aL{�ի����Y�:���#��X������('��b�>�ԳͰ����\�����`~� ]KӲ�kr|ċ��ȧ��J����A��zvf����Z:0��<����H����a�}�^�?ט�`i��m����̞z���ƔF���͠$�Vo)Ϫzg�����A¨�8�F�����a4���+�(.+o��u��X�-X~�!��- ����=���[���Y��AfJc�s�HϿ4w�9��� 9O\��@z������7�}}�n�6@�*}<�$I�$I�$I�$����O���JQ5UmJGr��1D��F2�<��4���=?kN�+��0���Ǩ:�4Œ.WQz�R�UѬr5�#i�ׇ�DleJ�X�6MqvӀ�����/w6�7���E��y���'��z�.M=�ge4+K1!��G�-,+���*�h4�ʇ�9�o�|Ŭ���������Ę��G��M����&3횤���LiD�Xm�.M��PmW�vYal+ι��#�K�0 96��E�z�E^�k�֔Fĵ��:�|a"S�Κ��aI �-u����7����� �5˞���)�"�Cy�)�(Sέ�&�rox�p�' |pt���G���\F���{�l5�o�t+�/N$�!�� ���;?p)Ey�?񡌭l7q({+�� ���J�$I�$I�$I��� |� W��Hѹm4ܔ�"��ྫྷ�2~���9�Acz�G����x��0�1���� ��N �ʊ�3adaZ���V<�U�� �����x�{4����ݐ�{�A���� �y�[o罯o�kb�ӽ����@/Y�*}�Ea�ME�mV��ù�Ė-~� ����_ycN�$I�$I�$I�$��"oq���SE�F�έ�fa5���gf� �Uke��Z�ё1=B��:US��_�+=�)J[�l&�dIﵷܝ�,_5�,���́��y6���p�x��P�)ϳ.�sfcxp_0����-R>M��A�r]���]z�mi���{�O��$I�$I�$I�$mD�<ȉP��:��*�Wht�t�dV@.\�"ͭ��z2}��g�p�]�r����]V�);�lS`?,����!�2�ݐL��h��/e�������Y!�$��������[��'�y!���b�N{nf69y��4����������'���IV�����7����_^#L��~l�1���=I�$I�$I�$I�����/'TQ�"E疊�k��)���3/6W?��­ =褳?�6�.�ꦻ�ޯ���U��J ��*���ǫ�JZ ̷�~7���F�������kl]��o�L���>���.�71��|۽a���i^����J�QM�&���goj>��{E�MF�������>�$����5xD�%I�$I�$I�$I��)�V;Q�WtN��s[��E`/oHox�����W���fŤ�xbE�շ�_�J�u�ʔ�$I�$I�$I�$I�$I�$y������J� ��ed-����J~�q6�Y�yōw�8��0V��X-�j͛i�u���)���)-I�$I�$I�$I�$I�TC�o):�+:'�f��Ur'>>�ż�Ҧ}�8-]v�_��>�L:��k�z���VfE��t�$I�$I�$I�$I�$IR���})�������P�)n�(�(���̔���T�8x�ڒ$I�$I�$I�$I�$I*����C�"_��/�;dJ���G�eE;5WJA�$I�$I�$I�$I�$�����T�ǎZ�ol��;���C�4VE�J� j�7�Ȋ��'I�$I�$I�$I�$I��KE^e�]��"��"_٫?Ҕ.�EQ�^+Eqx��pEV�^-,I�$I�$I�$I�$I��E��(y��(��J���V��\j ̠)]�8JE /D����iJG�@�$I�$I�$I�$I�$�x��U�V):�+�۪4�������e�Tt^���T�Д��$I�$I�$I�$I�$I�y�r���m�ȧ���"����)�`���e?8�>Εj����1�uI�$I�$I�$I�$I��*�%;S�vQ������T��^����H�������������>���>�H��R�~&I�$I�$I�$I�$I�T��W�@��YK��(�jCE��"����6��R�����7e~���,ݤ��*�$I�$I�$I�$I�$IR?(�4k(�N+y��"_���P�!W�cS:�`V�����eE(*��nd }"I�$I�$I�$I�$I�4���ڊ�� E^�E��S��fE�"O�J-M�(�(1��T�񆢂��F�n���$I�$I�$I�$I�$I�(y�(�>CE^j�ȗ���P�gE��"��+4����� (Jh��E2BQ��n�E�A�$I�$I�$I�$I�$��y����P���y��y�����O��g4̔�N /0�(AYA�L7�ST�#��B�$I�$I�$I�$I�$I҄*�.�*�D E��E��S��fE>��"�8���)�"�.�$4�TVT E�9L� )�hI�$I�$I�$I�$I��ɤ����Cu�<�a��ۆ"�7+��#/�������� N�.%&JxV�٨��)*���ԉ>�X�$I�$I�$I�$I�$�����n)�N��<W�ȳ���<��;�1{�y@��t(�(�`��(Q�Âj(*�:�n�p}"I�$I�$I�$I�$I�4����jE^hE�kS�g�P��F^p���r�=�1�M�2pV� ��2Qf8*�:�nȐ��;�?�$I�$I�$I�$I�$I�OE��HE��"/��J߶����~q�'{��4�7�2�шȋ��H`��(Ñ�Rt#�8\�Z|(I�$I�$I�$I�$I�4:E�c{E�"�tP��:�ȋm�o���y@�|f�4��@�"(.P&`De�+*�� ����6��H�$I�$I�$I�$I�$ME��"�4�V���wi�\x��<��_�=;c:��e`Qy�2QB�Ffxd�D�8�����N��$I�$I�$I�$I�$IR_(�0�*�Ly�#��A��n#׫�o�=�,�7���f��Qb�Fff(�Q�ąv+E7�zO�$I�$I�$I�$I�$��"_q,���*E^k��z�vHý���5yϸ�����ӛ��N��(�0*ZfdxfGHTpU�nH+E"��J�$I�$I�$I�$I�$�F�'Y���R�F�|����Jo����7l�%;��{�ޜΦ��#�.�|b5�Б��hT ���Rt㲢�?�z��F����Ӷ�_�����a�W��vz�w��$�a�^�]�>|O�$I�$I�$I�$I?E`�x��?)�\Ky�vHC���|5�G�1�޲��Ksz�ћу�!w�해��ק�������^�~t����O��zwDf���݀�F�QT���x߳nI���6�����:��Fs��.N�~�����/O?>����)7��k6-���w�K�>�D�g��ӷ��?��?�J����t�UW�5k� ϙl�P>���Ҷ�m�f�27 ��z�o9�g�}n�ت�kӾ��&���o,^�$I�$I�$I�$I�܊<̶ ���S-��^� �!�8���#sz3 ��_�_�Ĭ��^���S��Ł����Ẵ�Y��m�<}�� �N�^�f������0�� �Bэ��ywH��aJߚ���!ޑ~��B������9��4+��ؼ%��.�_�8��|-;~��f����6�mLZ���t�q'��?�7����L��w@:������1���H�_y5<w2i�ZL�Ӷ��^�]}/�| S���3�:�y�2:��#����OZ�d���ue���[��%I�$I�$I�$I���)�;Q䃆*|����t�N ��WF�{��t6��"3�_������dC�Ћ�L��|������(���̴�AS��N�.-[�aD��Bʊ �PtcZ)���~[�Z�V���[��<=?gQ�����zn���R��{���.��)}��9���Y�7���;��l�������Uk��mx��tϽd�z�}��.[9���&�eL��~�������қ�����7���%I�$I�$I�$I�����������<�H�w:B��Zz�^ސ��9�0�7+�3�-��Y��:�Ҽm��5o K(���>��G�濽(�����yE�T(*�H����U�vZ�����Y�f3S9 SW���ï�gJ�����]�Q��3f���m���ё�����)�^���7����;���dR'�4�=�����G+�W��$I�$I�$I�$IR(�-Gj�����"�u��?� �H��5�Ŝn�j��u�hK�y7?��������(�/��4ms��i��oMk6��3�«KҶ�]�����w�B���̜�_s�#�ܨ;�~9�~ҟ�I��/N�:������n"��Y�|���d#|�#�H�qy�멗��{����h��a`��5i������i�� �+��zv����;�Ն��KwN{9���k�|Q���K�I�/�?���}c�4�+�i8����@��\�!]��ii��|���o�4�Y?P�w<�R������(���= �,�[������oOI�s۰0㭫�tm�淾������}4�W�V��V��<fz��i9NL]�U�?�x��_���o�s��?o�:�����3�l �i���?�p:��s����A:����5�����%KW ��-5���/��߿g"���tWE�s��^î]� �?�x��W�|v���|���/�?oŲv݆a����K�$I�$I�$I�$��ϯSE^c'nR�Ό�������F2?ث�9=�3{SڔMi����(��]�׼=��^^8"���ek6��;���?������fS���������fn��`׿�n:������{�U��#�ܕ�;�������͛d����OI�cD\��G]zw���K�C��V1�>;mq���k�FrT1�1�1��{eQƋ4_vǴlo}Ȕt��S�q�ߓv:�ʴ�A�������Yo,]�v=��l|�X�>͚�$���K���Ά��y4�~c�~������<��!N��9�{���/���Ϗ�|�pG\rg�����77��O�}�j�m�s/�à��W�}��M�}�=���K�Y/��~�Î��#�N+W���'�N����Ng�}n�غ�r��E������s�k�_�sλ �z�i���ң�?� {�M�����9�.��G�é���+W���8+�˿~?M���fx�5 {��S��;��3�N�K�IE�s���?����1�s��W��r��c���fђe�ǞHW\uu���<;�����/��u�s��ci�*�́�~����q��L��a�%I�$I�$I�$I�&�"O���Y%oF��X��ƴ��uK�y�Tǜ���)=��mZ������D�D[FX ͊h��x~��q���fJ[��~ٔ�?8X�wO�����n~"���fῶhU6���gV1��#��O�4PAnhCS�� ���/mxk����Wܛ~p�%��g猨\&�b c��R[4�M��ЌW�����*�x�i�K ����+�>���_��ǔ^��y|p��Ey��C���z ��skZ�����%+ץ� �j �S��<n����˛�'J��WGaPί��}�������/�4�c�>�d��_�HW_s]Z��[��o�_��s��J���~y2�n��-�|~Tp��C� =��c������s��+�9�_^����}Xx/�qבO���JiVbs����?�H��������<���oǭ\ȟCV6�v�e�|��t�Q����o;ު|����װ���|��y��K�$I�$I�$I�$mt |�HM��J�0����h�&u��-�i�ť9���Ȝެ��/�)�/��ᗧ^[:̈��tfE4+�_0SzΠ)���ֽ� ���}�������/��~r̟�܅+G܌soz<msȥ��o��*fV3������K�d{��No,Y�+�����C��z-_�)}k���S�!ݑ~���G���o����gӖ��(��'�q������`��{��H�n��e�|՛�����Ͻ�f7��Z�!t��i��.M�f��<n�����x�z��=����X�&q�1i�~�f��[�(y�q����Fc� ������ '�� ���X8,,b �l�m�ƃ�f�b֖a1�1�٦cᢥÎ�/6�vy����7���S�<F:����ߟ�)�h�| ���w�-���v�7׿�^xqV.�e�W5�[��?;fe��v;�s츉c�G�r�U��2絴�Ovv_옏C�$I�$I�$I�$i����i\W���^� �Ҝ���Lj�_� �J��5�7�Ft;3����Tfoh����4�+��,����y�4��ڷ�?�Ǟ�l�A��_6�ײ�W9Z�l+����0�!��]��7׿�N����Uď�̕�����+��y�j�R�Ff3�R?3{AƋ�*�޿���������:�c�cJ�0��4ײ�b&�X�=�p]Z0P>vܴx���_��%�!,Ǣx&R+V�MGul��G;������/�9��><�_��o�s:����녋��=�s�|��8��7�t��^�ֿ�.������y���Ï�cO����_��U���7��U7�e���K>��־�V:r�]��t��Ӵ�Ϧ�k�7��xɟ���w�ߦ�KW ���X����C�]�U��Z�f:���Ҷ?�Qz��Y����kXyI�$I�$I�$I�$m�j�ّ ӫ�q�ʰ���W�F�0s5���3.=e�7�4��)=�TFj������5���KӴ��H�efɪuyO睏cu���ھϬ<���5Pp���yk��k�^�l�q����_5r�2z��U�~rt��z���K�їޝV�{+�z�Ci�,���0�����\�0�/Oϼ<? ���t�aX��a�ؼ�+�OO�&�f�\ˎc&ou���i/� k������Ha`�p�����0=���0 �,�4�cϽ� �c/�|9���O�Q�|�a�{�����M]^/X�4����{:�� ��i�K���7��|>��xM��4�~��iͺ ٤�n��s/� ÛH'�%ݤ? ���#;�|�;�r��t�}�_����w�5��/��E:��3�ee�xɟ����E�mW>�=�p~��?ߐ�w� �������%I�$I�$I�$I�6y���Z����j���a�u��a�4jxƥ�\z͑9��PFP��&q�M��6�|���k C�;�l���`~@�֠)=��2�;hJ_�~�����eC[5D7 �U���g�ϸ)o�1m���ڸ4wY�Zj��y��?:��4��7�0^']yo^�}���#ޛ�Ґ)m�^[�"�t M�e�ʵ��N}*�3��G���@���Î�8�{�!,Ǣx&ZW�������K�m����G?��l��r����ǟ�qb��z��%�{�W6�-Y>,l$LW�'�����W��9<�/�x)�����t��( *ӏ�\�A~|xc�����{i���w6��}���ٱve�1���mW>�Λ�ˆ2"=�a~^�$I�$I�$I�$iS��(�*�?MUf�ú4�kեA� s:��� �]^|�� ҿzY6���=3�Mo��~:�'�������(�p$��Џ�Y����W���ٔ(P�6���6�У���*���# Z�;����6�LIW�3��ޚu�0�M�+��f��l�?��L6�/����M��F�q ��]~w�ث �7M��+�4���|��/5�-[�.t��i�#.KO��Z�c�G�r,�g�Ū����l�bz���UW��i��q���1{ul6��9���5���[n��|z����������Ϳ��8��/�z��ҁ)���Ae����9� h�=�䴼›m2,b�N���>��qoJ�1�a�:��{a�MvCX��+�&4�a��-wI�$I�$I�$I��ɧ����&;Q�"oN��2�K�z�Q�¤�Ƞnxʥ��ӛ�u�hK�����[g�Z��K�ɫ��=�x2���^H�v����{[�._�����2�0wQ������.�+�}��[��}φ��r}zu�f�sC�>>#���G�y͍�˛?� �W����"��_^[eZ�6֢�k�a�c6���x������)���+��3^o_�b��*�.I��ю�]�<�lj�[rp-;~��O�7?�B����������ޚ.]�<���=��q���^j�h�\�f:����M�s�i�ҕ�޻���������潱��ނE��~��]��]�#�zyn�����i�sv��̳�o���w��n�E:�Ϫ5���>���ӟӲ�e~�����y�f�R\�k�LC��,�X>.���.�����-�o��b�_���/�Ǟxjz�b�m��Ǟ8��~����6��(=�����xɫC䟲)����a�x���{�Ƃ%a8I�$I�$I�$I��MECFv��ÌMj�7���9�5Z���A]z��O�cNgS��=xaKȊ���Ο�WCo}Ȕ�_��t�w���2�����63LA�'�w���|f�#�ܕ��sX��Y��l��r������K[xQ������ܙ_�u� �h=�����ܬrrT V�~3q��\����[�v}���W�ߜsK���)�Ћ���G���g�ٹr���:y�����Kӡ������˱W�mʉ�&,�;Ȕ^�lu���O��aw(�O}lF>�l��?ݟ�#N޳�9�{��x�4L點z�y��hɊt��H�������l�:�l�����1��f�<��׫��.��Î��N=����w�=}�K��[fS�¯X�.��><���CrX�O:��J8LW;�����3r8��: ���M�( ����o���/�Mi��<���~�ßsޅ�~��҃�¤�8�&��n��SN;3�r��x.�pJ.��?�x��N�,\�<���r�+��6 #I�$I�$I�$I�4�x�U��d]UבIm��i�&u+�ڛӥA���V��f�1��%h��w�O��~~�ui˃.�{B��[xI���k�ٌvZ�fC��i��G]���~i:����o3��/�U�o|f���Ϋ���xu��]���c�Y�bf5��BQ ��懟�������<��]��Vg����o_<BØ�hŪ7�J�=N�6���@����{Ӄ�_I;;h2[�9��O�&0p�KW5�/]�6�s�#i��.M�rI���k��|�tۣ/�=�dہ� ���Y84��'s�zrְ����+צ�x$����{[l���_��~������*���>?s�9���/�f#��?�a�t��e���?�5�>�]���ċ��{�l����t%��}r������qF����X&mϽP}�.���s1�Y�m���]�<�6Oc����l��_6,��l��c���[>�����'y�v��$I�$I�$I�$IҤW�!V���P�ِ���:1�GkR�u����|b;3��X�,���uo���t���g3���g bd!D�� � 8�h� +n�J0Pa0�O����'\�f��xd��!L>�wb;��n����@�ϱ(�x �S�|��ya�MY��>�!���Z��H�$I�$I�$I�$MvE�aNJ�ˆ������<ҺFu�͢N j�z��ţ1��)��ڌn$�g���^M?9�t�ew��$ʂ@���­e<G7׉ �� ��?��t���'V���8glZ+�ԓO?���8���Q���ߟ��v��٘�(��l�z��� �؎ޗ$I�$I�$I�$I_E������*�/C5��a�hm���I�}]� �N�i�7�Ҝ���0'��mnydF��,^�6�e�4��B�ک��`t�}O�}έi��.M�����K��UڑZ6 ��ԙ�X�4-Y�:|o<5��{��Ǟ�������?� 3f��6E-Z�2����A�����v��>$�:oaV�$I�$I�$I�$iByucP�V�{�C�<�R�����I�եI��i��\��љӃ^s�1�Mi3�CC����|�}��Ѿ�F��A�G7�4���?��޼/��r]z��#+STY -]�f�Z.Mf���)i��� ���ӓO�= ��j�����OI��r�t��Ǥ���$I�$I�$I�$I�&T�g7JE�a�J���Ƶא����_��RT�ԥۉA��ߖ�tca���[�ӛ�!�O03�iH��\B�O$��2��jB�3���6�� U����Z�|��L�$I�$I�$I�$I�� W�ݍB�X�ȏ��-�*��n�c1����~�s����z���9��ͼ!m��7�����0jmD�0��0:��|v7n� v �@YQ-�x�Z�J�$I�$I�$I�$I��~Q��u��?�T�Gz�r� o32�K���R�ϵ��vbP{ϷҜnx��VMW��C��7fH7N�:�q�N�h��`+#�,�҄������v�]�*PVT9 -�$I�$I�$I�$I�$IP�V*�#�g9L���y�&�3�K��4�K/��A������hմ7����lJw�:�f�/TiD�&td<#w��dW� TG ���$I�$I�$I�$I�$Iʊ<�N�=˦ _���恎Ƥ.}X�Ѷ3�͘ngNw�jz�Ґn�:z�=��ft#���Q�Ѝ1�&���dST�Zi���$I�$I�$I�$I�$Im������Jú4�[� �՛�ޟE޻fPw`N����i[�\�jz�V��-boH�=ˆn�����&t�ݸ � B��EQ%�4Q+-�Xo,�$I�$I�$I�$I�$���x���Պ<�H��i*=�J�y�:0��A]����-WO�ɜ�v�t6����Ei�/N[�ݒ�N[4�/J?�/�M[tI�������%��^o3�wPC�o{Ȑ�k���ݡ�����Y�NT����?lJڞ� �0��Tu��Gh�6���ӎ�^_�L�$I�$I�$I�$I��W Ǧ�����u ��Fu�J�Ƃ�usڌ�Ȝ��8Fl���{i�Ȑ�mF\��ޔiF�Ft'&�ˣ1��ɑ�:�xѼ�K%I�$I�$I�$I�$i�k���Fiv�����joRW��naPwjN�1=œ.VMo���V�tiFcD�3�͈n�чvDŽ��gϑql���!]�BQ�j�t�Ƨ��X"I�$I�$I�$I�$I���/�Hu��v&�X����~��Js�ӭ��U�MS��� �Ҍ6�ٛ�fD3��_gB#g:�1������ֆrd�65p^;�d ܦ�W__,I�$I�$I�$I�$I��t���n��� �Ҭ�Ĩ�Ġ�[|D���ӵ��0S���ѝ��M#ڙ��j�&t=�y�j�V�rd������Б�7R͙�H�$I�$I�$I�$I�&��F�/��vfwhX{�/LkoTwhR�3�G�A=b���1ݩ9ӛ�|e~�1��4��7Ҝ�™�p�@�VK�$I�$I�$I�$I�$IҨ�)�ߌ��=s�fi�h3~��i����ɒ$I�$I�$I�$I�$I�4�;�<w�0sz�y V4 i�~��'��/�LB!�B!�B!D��/�3��d��a�yl�����:��_4NB!�B!�B!F~���W�kӛ-\¦֫�s-�B!�B!�Bt |g[-m?�����B!�B!�B�M�=�5i�� ٘n��B!�B!�B!D�1SɔB!�B!�B�3̃^�v�Li!�B!�B!���iJ�Y��i��B!�B!�B!z�y�+W���i��B!�B!�B!z�7��Li!�B!�B!�=�<���ɔB!�B!�B�[̃^�r]6�eJ !�B!�B!��C��Z��B!�B!�B!z�y��V��ƴLi!�B!�B!�=�iJ�X��鮘�˖-K�������7BL.>��4s��t���g�?����s�=��򕯤�n��q�s>������7^ !�B!�B! �._��鮘�GuT6�"���?M>�`#��0��W`Ln��#�����~�j�`�[>����Zv�~����.˹�.���~����a����￟��{��;�+V4�N,���{�m�f���{��^�Yg5� !�B!�BQ�y�K��=7�M��~z#�豸�^/�袋��9�5�\�=:��A<^p-��XVw+�}��7]p��(�?��qFo�)���A�=��3mذ�qtr�M�8��%7�pC3�Li!�B!�BQ��)�lИ�)m��yƌi��vk�7VC���)�M�-��"�0���c��X�d��CXYLtz��}�dś����7�V5U���;�x��2��B!�B!D̃^�tU6�{fJ��ޘ��������k��G��p.���,���� Q8�p��mH����~��׌?2���{�i�5���L ��8�\di�x.���|̶��𤙴�D�e>8f�K|�,\ˮk��s<!��g��`��_Ix`6��F�?��ƻá>}��_M�~x��C��B!�B!���yЋ����t�Mi�t���ji����߿��Ʃ���ȯ���z������*lo\�i+��&6f�����'��}D9yc�U��q��t��h��\'�<�L��7���������=��a�Ι3'׷���:_��S�NM�}�YgT����^���+�^Ѽ���}-����M���j#� ���!�2l�k�����|�q��4b����i�,��w��'?Ik׮m�;eF�� }��JS��t����|�;�2��꫇�3��/Ҵi�����\&��9�{�N�b�?��㹌�_�a��v��eGf;�=��S���x�G�y��yz�?!�B!�B��oJ�q1�����7y����v���V����k�q>���1t[Q�U���l������2NV���4r ��Ǎ,�~�LA���x�����˃4p�4M$��Ven`(����w��8���c�i3-^V�bb:�x�M#ч�Ȕ^�n]�c�=�����9ij��g�s�V��w���|] ���;/��׿��%] .�a'���)S�q���R�H��'��M[•�4�v�m���N�ef�eu��_~�e6�9NQ.V�c?a: �=嚤m��w�a�s�����c��H���׿>”�E��B!�B!6̃^�d����fƚA�M[3� ˊa���z;����Y�X欅���#�qܩ)mDq�?N� �.o(�9��܎�4U�g"�y��M^�G��x�wL�W����E F���ÉO>��q4���-�N�L���/i�wa�ϝ;7ͬ|�����V�tiB�����׻������� iVJG?x���ßc�2��L ���zkof7�����>y5��qڼ_��I��^{-��g?�+��������~g�m�M˗/��H�e�]��U~HA[����t��'�B!�B�)`��+�1=n�t� ���qU|v̛�`�x�����U�%����d�y���Z���?��Z���i�J�Dby�w�}�1X�+>���F�A0DY���Lj�m���%l�O<��ce���U�ٌA�Q �Li�j. ^�������{2{����K.a��"��L�^z)���%fҲ��c��4m�>���?���|���� ��d&����+�+2���ʟB!�B!Ħ�7�Ѹ��毇�����Jy�Xif��1�R�_�<� �+�˴bj�{~K;Vb�'�)�Iz0�� x�k��,^̿LF�F�[���O�13Y�t`,�=����>�ai�7S�'�?�s�� �QVI�Z�s�ʼ��,�_�7�m�����K/ͦ��<�t��������ɛ�v���)ݫ� !�B!�Bl �=���5��}o�zs�J;V�~��*�F���a�)��^�i��3�����]�U��a�n��s��Y�dI�j���~�Ѿ�odJ�������ҋ/���4#ul������[;��������4�-&0R٪�<�7Z��Gyd.�H�Ȥ�f�r.&�)��2�u�R��{ls衇��~8�3ďaF��g��4�=U�t/�'�B!�B��c� �����ɔ��O�J_ .;ƞ�~덪��7[�~ ��~��I(2z L" �>�U�tٖ ��LS7Mi�R��jU�vܧic1�Y���gy9����x#S���V+�1)Y)\nc�ټ1������/�C��RlEz+S�ot �C����rf���VaI�؂�4�K����r���@�)��� !�B!�Bl� 7���ޔ�P�ǽ�}3���� [��f�7�Ksӌ$T^����`���_��v̧ �����U��Vi�+�-._F��vܧ�*=�幓��'4�ޅ^��G������b�F�t�=�1K����YE�1�Ҭ�&���!�T�Ð�3�Ye]~HP��/�����oӛ}���0�Iت��A͊ho2۞�U?:X�ҽʟB!�B!Ħ�yЯ/\��鞙��Yސ�U��Mi���G;VeJ����e%��W�%~57���Ⲽ�����d{�Ռ�2��� ������a��cZ����L�իW���Na$b��{l�av��{�y� 3׭[���c��㈳f�jiJۖ���l��8 �1�Ҙ��G|`�p2:��������a+��Q���>�i��/����LۓN:)�$? �����U���{�=�&3�/����m���>|��'�B!�B�)�4��Ȕ�a�A��j�n �Fo���9�c���LW�ʙ8�nj��F�=� �1qmo ����W=�N� ��A��m��Mf�ٛ�~�K�O�D`y�w�}�1 �CC�m;Xe�jg�����xX���H�@ej��7!KS8���>�ԯO<1�/���=����) �/~�����s0e1s)�_��׹�O=�Դ���{�gr8ʞ���$�������e'a�C ��o8��/��q���!lj�x�_��{Sz�?!�B!�B�M��-X�WK�ܔ�H�2?1�1m�&�7��jfd�+�d�am���Uڭ�+��Hg�y���2�>]�4��2a�o�C�Vε�) e���2^�<WɌ^۶��Cڛշ�~{^�j�r�a�<0�1���Li�={v^K�Ԭ��Y� ˍє���P�2�С��Ï��??����/�|��F�A�o�?�x�Ѯ��������\���E8��,��;F�c`t~ڴi#��0z�?!�B!�B����)=i6��bJc.c�xa��v`��{��/����c.�5��O�i����B\�&���!\BZ,<��^�y(㷰�\��>�V�H>-y���<Ge��A�(G�*V��؇ �n���Y!�B!�Bt�yЯ��$�]1���1#�Li1zdJ�:�/9[�'���լ���B!�B!��=ޔ~M�t� S�{Ȕu�[l����l��>Ь�fq�-�.B!�B!�c�<�W__��i��}�L��!SZ�eŊ�s�i�;�I��5k�4B!�B!�B��2dJ/�)�O�j�&D�^�B!�B!�B�M�羾8���)-�B!�B!��g4M�y��ji��B!�B!�B!z�y�s�-ʫ�eJ !�B!�B!��MS��Ey��Li!�B!�B!�=�<�W^]��i��B!�B!�B!z�yгeJ !�B!�B!��5ޔ~嵅2��B!�B!�B�)=wA��C��B!�B!�B��a��s���2��B!�B!�B�!Sz~^--SZ!�B!�B!D�0��9�)-I�$I�$I�$I�$I�$I��4[xȔ�$I�$I�$I�$I�$I�z�ASz���}Ǧ�O!DoP"D��)�B �qQ��DmS��v0�7�1-SZ!j�>D��DmS!�B���ڦC�@��Bt��!��M!�b��B�'j�B ����eJ !Dmԇџ�m !�Ch\�?Q�b�̜�z^--SZ!j�>D��DmS!�B���ڦC�@��Bt��!��M!�b��B�'j�B ��/����)-�5P"D��)�B �qQ��DmS��v0hJ�.SZ!�>D��DmS!�B���ڦC��ŗ�ɔB����?Q�B!�и(D��)�P;��f��Li!����!��M!�b��B�'j�B ��_�)]��O?��>��t�5�4��˖-˚�|��Gi޼y�o+�+匄�wԇџt�6��i����W"bʔ)闿�e����G�BL:�ʾ��njٳg7�!"ƻm���0�b!�k2�[p�m���|�+騣�j�=I\M����N;-�㢋.j���< ���?�m>�������?m'�xb.�+���qD!�d��q�����kBD�w�l�[l��. �Dkl�L��c����^�)]� ��!SZl���?�m�)��n�5����B1y�d\�6��)-Dkƻm�C�t}�]uk���+-S:`" %�T��$��j�b2�>D����� �=����ԑ)-���N�űb�s2��h�x��v����h����a���Y2�+1Ci���O��~z�r�-���>��k��'N4vη�L������>K��;��-�e�C��_܌��/�_d�pN�y���N��(��q���_{���$D��>db��v�f��q�Ge�X|�o��H;}�|��ƙC̘1��'���2�bb�mR� �����=��B}+�W��+��vЮ���g��O�A�p\�ӽ�}���qk���tY�yO��BL^:m�c��F՘�_$SZ��t�6��́�Q�1g$��g�K�!��y��|��y��jʹ�C\sc����(l+���Y���_ ���vsa++��]��m.�9� i�+�*�c� ��/ɔ1C)��WN���clj��V�KY���' ���(~���3 �7$/[nDa��� �(�U��wԇ��_��G�IX����\�ƶ|(�D�n�D�M۴6��M���� ����/ ��G���|`[`�br\;Ǐ�`ǭ]�k/ޓ)-���N�E?����a��|8��B���� ���hs�ճ[�o��۬�y�c����q����/se;V�����cy�k7�������3�</S�{hETl���ܱh���v����=,�A�7\�Q��`�p]k4>m����C�5$�x-.L��쵥���]6�*�����o��1� /D��>d���v�429��`��'av��� ��K>߄�e�����I�ѴM����p�߾�"��F�=j>�}����옥Ƿ)�/��5�a���Y�c���\��M��BL^:�8��ܰ��a�eJ њN�&T��v�n���y)��jsL{mm��<�^�g-K�}�p�W�+��?�������O�埋�9�^�� S������v�ϧE� k���+-S:�*�=$v�O��*pΎ[�&�Uj:�!�E���ǰp��ji�F_ٙ��!�E�u”騢L��[�!�� ����>�(���ȧ�L7��ge ��1�h�L|<����e,m3�/`m���n�>p��COY��� �_�{�ว������qk ����)-���N�E?����h��1Î˔�5��M��\�g7[�cs��$������C����Lj���K�qUa�v���ϻ~;����\�j�]���D1:�<?�U��UP!�l��h��*p����<���+�7����i ��V���òO�� {^�Ǯ�0����}*U�2���|��,D��>d������$n�b�y�ڟ�����H���8��6�� gX}��i�����갵��B(��ύd�vXx��aǭ-�� ��B1y�d\�� ��1 v\����mB��l��J<�� m mJ�,��o��d�P3����{�$.?Ī��m��^.KG9�n7��}�p��cblX;Ȧ�,��!V��C'��*p.�؜���̚���i ��V"���1�%�ô��D�։�0��'q�(�]��(�B�+�C&�1,.KO�vγI2쵝Qy��,-�$&����v���V�8u�&,�=�Y�:l���:�Jez���v}Î[[(_2��b��ɸ��A?D�c�Li!Z�Iۄ���ܱ��տ��1� ��]%��z#ڞ��מ�X�a���—���j~Us�vsa�� ��P� k�ɔ������ �De��bS�" �0z�J^���'`�V��I�VV�}���:*�rm{�.W:WQ����ʈ�,D��>d��î�5������3�� v���{%�����v���V7��M����6���6I/�ty�ؗ+�;�4� �!k �kC��BL^:��EcA4>F���˔�5��M��\�g7���A晞2���P�la��k�b�k'�OU��ϗ��nso�fݹp9g7�p�g$Ɔ�Li���)`�4& �*,�`�h��Z���h\v��{m�i ~"Q6`�[�eq�_.��-?4r��NM�2��y �kxCK�~G}���!��&~{mi�a� {�yFT^`y��>>�q}V��cbbMۤ�A�z`� ��v�>tm׆� �>����`��F�p@=���c��tr]÷uk �kC��BL^:���ٌ��)��2��h�hۦosu�݀�-lގ[���C��E6��ϧ��^+��峦�iɛ���������sa ���k��ذv�� �ҕxS�I�Gd�7r��A���0����1CT��6�(~K/��yxc����v��9�# �ٱ��J�n3�0���_ 1|����c�M��oZ���~O}���!`�X�m2d��/cd'{m�AT^����/��FV��U���n�v��Ճ��Zݴ��i;��G=���1&�P����Z|Um��,�Df�#�uG>]��׆Li!��X����4}�����ۦ�S��/����N{:���c��4{]�v\���϶Y���<�����gz����<ԧ��֟��z���&/峦��縤��2K�l���sa�ۗs�2�7��f�9��J7�ݲ)=�U���0���0 �M���0�����@e��F�B��ɒ���o�^f�����D>��F+͟??L7�,�����5��N:蠃�un�=��U2�}X\�n����en${m�AT^`�����{I�l�#F�D�M���ΰ��W��2�6�;&��>>�mԆ0�)���x�]�6�˲��8�-�� ��B1q`z=�����f�կ�[o�����ɸu���u9f�q� !6fƻmV����n`�o�Wb���[�C=6�%�'�ޜ9sF�W�^|��.�6���&y�����=Cݹ����=w��E~ѭg��f̕)] ���_*6��F�+���Tb ��|� �hp�����* ���[Z}<��}�@�2n ^��y��?��Y�t�gT��x�7�Z�-/B����i��i�wV_;�@Շ B\ՇD��עL����U��q�Dǁc��Y��ؘ��i��]=(�����w΍��6�96�-?��tY��<�5kְr���C��ac��UK�����1�,Y�8"�b<��b�ć�^ַwb~u2.6>�q���j�0c魷�jb�c"�fU�3�KڼҷU���%=U��9�<�ca�9qt�7��M��"m��֍��}����i3,���m7&^�y,�������g7�Ңc>��t�g�Խ���-D�'y|p�@���#:���;��5�CƎ��ٔ�&^�Z�Mz��Z^���a���a��={v#�B�Ʉ����q�4�Gڡ9��Emsl�p� ����X�?�~vÔ��eJ !6Z�%쉵�>���@�����;S�5�C���Z�d5���yE_�B�ia�׷������{�9���{�ӆ gT�9��CmS��<�=+SZ�1c'�h�r�-y�/&ց�Cw�qG�h�A}��aSm���������vT}-Q!Ħ�7����t�!��q��}3�0�֭[�8�5�� ��6��ݳ�Li!�FK�q�d({���8A}�cGmS!����2a~�'�x�E�cGmS��>�ɔBl���8_-��<C}�cCmS!����~��_�^�ih\bl�m ��g�lJϐ)-�؈�U� �C�=j�B!��2�@��GmS��yv{��92������[�w��u��>D�ѡ�)�B Q�^Gy�q�����B��M!���M��b��:�o}�[�a��q��!:GmS!��L/�í��*�����E4� 4. �9j�B�ﳛL��a�����\���u/x����.��Ҽ��=�\�!D'�v�m��\�vm��������8aS�+��&j�B!�����3�FV�ٸ��jz��E!:GmS��}v4��ʔ�0S��3��F�|�x��|��g��_�7����Ք�|*������W_M{��Wz�GD�� ����͝'��lh�:N�v_ɯԲG��_�?_x������P��FmS1�1����}&��_�0����"�9���s��鷶���oN|pڰaC��e<���.S�3��!�_=��r��;.�\��r���:+wjtnn�\�7 �g�1�[���ͬY�r}�6mZ���U�>m�JO?�t.�nu����R�W��u����/}��G���S�6E�Q�BLf��bld�d��a��5� �=.��3�=g��~k�̓/�첼�H��/D;���M�t Z�Ҭ��>}zS7�tS�sh뭷N���o��Mi �+��2�����{�7uS6���/��u��n~�gt����u��7!"�6��M!����e���a2>gF��BT1Y�f�d�ˊ�g<��dJ���) j�јҧ�~z6��|8�&����_�z��o�Liu�blPwhk���{��'t����u_Ɨ����CmS!��/��"���?���ƻݡ��"Ȕ;��mFLֹ��x��� S�ٍɔ^�hQz�G�F�I>;5�1�O>��a���![u�e[w�qm�5���*_�`�<���v�)=�����,<��S���/�����=a��E��ꫯ�f:��O@|��+��{�g���R)�Ν�����h�kn����F�A�O8ᄼ? PF\�˗����ө���ϋ�A�RƧ�vZ��kr8�,�7o^��w��W�{�/_���v�t����ה#_y����L/�gp2�������4�᳏��`ckʎ8�ɜ���3��qp?y���ϯ}����a��C�4DyݧӾ���O�:uX����q����N6�|�m�N�l�hK������cЪ��mr���=���X=.��/u���g4Q���O~�.��a�m���k-�v���&eI9>��9���K/�o|��}�����u��s���mߗ����CmSm�^�m !D��"�\D�l�v<�-\�����3P���:c}��Yg\�zδq�k�,~�4�zΌ����s� 7�dٲe�#�0���h�z�:���I�1>u��i��ܯO>�$�1|Y<���̢<���i�d>G]�N���;���r�)ͺ�9�{/�3�yp�>��cu��wD�����Mka#1�iT4 i:�*:ɧ�ľ�F�<e��_�J��?<����n��s��(�9��s������΃A���m��[ێ�q�� �6hr���^�z vY���;�;� �� �>?��`>��ôz��<8"��4�>�h<���y`������n��oҽ�;�2'l�=���i'q�d��y�eE�P�ݑG�L��1�"=|��"L8�g���q�Ӕ)S�k;��k0Ѡ|H?y�שּׂ,������;�Do�����1��OfF�SV/���zB}�޲wu����[7�ڃ���w�=�1�"m���>�]��\���-^�8�a�4Ҟ��>��˼o�%�-��"OX��+{�9猘|�N��2�:���&"�We��T|PŘb�"�����X�oi�>���9��j�j�u��m !6:��F�m�?�s������sfݱ-z�\�fM�q�و��ײ�L��c�e>�����k������9���5�3_�=��S����~y<�;_���h�3�u��e�" EKq��m���i����n� �M��3�w^���<�����ۜ�����a��W;����\��vH�2c��S�.�6 SC� �!}�E�N��N�٩)���x�:V�2��!��8OS�������X��뮻�M�m�k���-��2?��*sΌ3�k�,�>��ay��A�k���~���.�~�̙���3+��!�����ʑ�S�t�?��O�uXt�~�}ʗ�E+��=��`��HZ�7�IZ^�I��PUƖ/[u v�la��}�J�=�3Y+K���?+?0���Ib������D[��[��~�I&m��ͪ��d��?0I���+��1PN����[o���F��PIe~#h#��+QX�i}B�|U]��E9[|��� +��������F �.m���CmSm3�KmS���ɸh}��~����o6���|I�\� T>g�ۢ�̺�j��L�����<gV��� �a*�2.2>�D<gֽ_6/b^���3�L���Iۄrn��/m�:M[��ea.����YiM����������o�S�샚(�b����FaJ�0�!ͧ;��D��4ԋ/�8jd&"�X ϧ�4^>�����:}�h���ͯ���S�C�C�\�Q�W�<(�nj��+���W^Io��F~u��m� � ����cl� �f��5l�PEY�Ueli�3�cf�CynU�Ym�D������oί +�:�c��>� ��İvJ���>0�x��m�k��Q^�n��� ��F�e�̇U�_��{x�ɷ����(��Ꚗ6����u�*��>�+'^���"Ɔڦ�f�ڦbS��q�>�+����5����˱ͨ��ӝ<g�׮��i�=S�=�{ά�o�eh&7�B÷�5��9��̪���Eِ��Ci+��|16:i�P���� >��9�7ќ��d�ڽo�=X��7װp��u�i`� ��/Ι���߲��fH��)M�^����?� ��? ��jE��]��G�JD����#����ڬ�K�N����k�ݟoeV���(o��YX{�����>�ge7���a��<Q��<M�G�|�!ۧ�����~�s��o�ە��]�����I�=�m)"����:u�U{��d2k{����Ui����1o)���5h3��|�ƚ�Tƒ/k��'�~���kAynU\v����/?~�)�cGms�(o��R��0��B1Y�d\l�7z/l���|^l7�+σ�>�y���1�����5�/~�q���~��x?gV��k_����������mBy�� �}8��6gǬޕ�x�ꎝo�* W% W�f��b�`Қ�t�| ��𪢓|Z' `���c��Xk�!�]m�e��:y�X�U�~ԩDTu ����^?�U�9K�ؒ�]�����bE��jժ���2�JKI�����e΃*�%��ᵃO��+�|:�' ��?��?�������dž�U�l���J/&b��Q�[�~;ޮ,����_��N��oKU����u�fU}b�ʹ<�! ���RȮ]���(oc2�>bQ�m��� ��q�=t#_��$^{x�+��s���V����� Ly�;j��Dy�ڦڦbӢ�q�U��z�5���b�1��?��<��f��=gֽ0>1N�!ҋa쿍;ϙUq�ڗ{4w+��|16:i�Pޟ���}�hnd���M>@)�>��շ��|�WY8g�q!��BU�Ŧ���IkJ�Rn�1���?֊�������t�u��e���=|���حO^���~X���tz\���l1�,��Im_�58�Ow-Q�i����7�t�^��a+�}��\�~���Z<d���,Ӫ2�+�0����� �s��o�--Ui+�[:�C�����A�N�n���}�[7����*��(�]�����` ���U���k҆(K�U�=@�|��&N�y�}p�xP0��eǭܫ�H Ly�;j�j�Q\v\mS���ɸh�ڶL����3˱��^�3cg��Yw\���Y>�B��̪�V�8E�y��yCޘ��̪�x�˽���+�c��� ��.j7�q.jsV�ʺSR�{`��BE?G��J��t�v�� �L.S�O ͐.��,�4?6�1���������?e e���R�;���r�(V �I}�N���C�����ʇ���E{>5�+�������Q�Ƀ�I'���N����7�K�u�� ^>��a��|������?Uw�V��O�4b�S�[�~;neɽ��c��t҇�ʂ�Z�L�i{LT���_�nV�'^�Gط6�6�9�]����:\ϰ�� ��1���u��o+��_ ���6W'_��im�[��V~���]ynU\v�ʝ~���I5�cj�CmSm3�ˎ[��m !6:���4��o���g ^��źc[��Yw\���i��3�}ά�o�Ĺ�n��O���5;yά��׾ܙ��ǏN�&�s����}8��u�9%���<��o�+&3��z��f��;��9���IU�Ŧ���IeJ3�0@Tm��UE'����X+�Ġ�3����-�V�>������&_�`Oh&[y���C����t�-���9�]�gu�%}�g�U�l�a{K���x�f�����ϻ��J.:G���9���H#��!�O�H/Ҥ��Z�X�jL:��:_� �u�=���_V�UelPO��q_���U��QY280I�Lv�i�<�t�1z:�C����5�\��/+P�_�+�U�;n��nݬ�O�=²]������jD;���}���ھ�h��:�g�ɵ�w�6�f͚����~�\qu�U��s���ܪ��/w��;��c�F{-�cGmSm3�ˎ�m !65:��F�m�3��EL�s��k��Xwl��3뎫P�9Ӟ�~����06^�yά�o���sJ��n��]���̪�x���� <�3��� ���<_��N�&s��%!j7�q��y,6���p��ߴ�u�L�ރ�c^I���q]��CU�Ŧ���IeJ�۲ë�N�I����%:֊���ɑ � �w�N�N��.˃� �SO=�\�Tw��9s�ds��tV<���WPWu �|�INy`c���/��I�����g�Ν��O=���#��E�5�r�6���r��\F�����,Z~��[A]b�Ut���SN�y��Rv��}�]U�y� ��Ŕ�V�ߎ�4/;+ӈ�{��C��$�b�t�Wb�L�:5�/kg�6s� �:FJ��YU����k��+W���c���;��1��>���|�����\�`rk��*���r��n_'_u�IG9�+g�s���e�G}�i��6�|1v�6Q�l�@mS����<#1�0���nj�9��^�;�U=g�W��{�$�}�ݗ�%>o�{ά�o+X�� ��9�*.^�i���1" W�/�F�m�9 sH�P�n8��A����fa����sM#j�U�+��3�����ܹ9�J��t�v0)Li͐n�e�W��C��`/��ӟ�Й�Ix�}ʺ�� W �7�s_)F�r{�^�A��_�Gms�DmS!F��ō��|�|���Y/��L�)�At k}oJcH�ݲë�N�i&1�D��~8݆<��c~�u��>�ʯT��g�}vD��|}�O�E��׾R�V��j��`������������J�*'����ƇڦB���'�x�d�e��my���|0�Wˋ�3Yڦ��K���)m+��l��UE'�4S��*����^��dJO^���������\���� �����?_��_���_�J�9�\����Y����{,�k{��>�_ .l��Bms�AmS!Ǝ�ō�^>g��0{n�����mX�i-��dh��D��v�צ4��t�e�W��O��� ����� �n��f�s�~g|���-��C}���±�j���݀��Yl5��c�B�/�Gms�AmS!Ǝ�ō�^?g�-{ ����,C��L��)�A�k}mJcH��~d:�S��O!��A}���ڦB1��E!��M!���������ɦ�O!DoP"D��)�B �qQ��DmS��v SZ!:@}���ڦB1��E!��M!�ځLi!���!B�'j�B!���O�6�j2���ԇџ�m !�Ch\�?Q�b�<�Li!����!��M!�b��B�'j�B ����$I�$I�$I�$I�$I�$�J2�%I�$I�$I�$I�$I��q�&�}�������sԇџ�m !�Ch\�?Q��βU�{�M֔��o*�����?Q�B!�и(D��)&���M��~�P!:@}���ڦB1��E!��M1���n�ځLi!���!B�'j�B!���O�6�d 2��)k2���ԇџ�m !�Ch\�?Q����HȔB�P"D��)�B �qQ��DmSL"#���v SZ!:@}���ڦB1��E!��M1���Rs�X�f�^���1/��9�-e�@��Bt��!��M!�b��B�'j�b2ɦ���e��3^ �{���5Y;�)-��>D��DmS!�B���ڦ� DF���!m"Lt��ځLi!���!B�'j�B!���O�6�d 2��sD&t�V[yX;�)���r��t��{qDL&6lؐ�?�����}-���i���÷�v[�����,X�8�i���!���j�k��� /��8"��Q�m~����C��19)��_~�n���t����r<�裏��_���勞|�+i�m�I�~xz�G�?��F��q�Yg�]v�%���ۍ#�gSmG�=�\�����3��P�/�g�'u�ݮۢ����b��d��g��mS��$2�Q�UҦV���L�)��o�+��2]r�%�#���|~����^K�sLz��GG��g����/����!^;0�0��<�Ȱ���duٲei�vH7�tS�Ƞ���k��vJ��~{~Ȫ����Ӷ�n;".�ˡ�`8Zӳ]9�y;��������vz��G����O΃�{�7"N��Y���w\�`�Ä��g�I��{��曧k��&}��'��P�0����o���c�eR��o~3��=���Ȕd4}�ڵk�O~�t��G��}�~і����翼�6�f���{ڴi�#�ϼy��w���<��"�b�P�mF}�d�z�����c>�p� �#���.��i�n���i�ԩ]﫺Iyi��a�]wM�֭k������ө��:l}ꩧ��v]Λ2eJ�>}z���;�v�m7nul"������駟N;�s�75S���駟���,���P���m�9�����կ~5?�����Ms��6G�ψ�����sNZ�bE#TRwκ1��U�շ�M��+&??�d��g��mS�^C�g[����HF��ad@G"l�v07y�(0��d�n>1}�Ѧa�j������/�Lj�x�lԶ�&9L�����!z=Y��€�/R �\pA�1��IZՄ����^��o7��) <<�⸜��0O1���#CڎGqZ9�q��<M|��V[�����簀!M�����1�yM��k�����6� ����s��-�ܒ~��t�G�E��ÅvȔd4}%rP�zQ~�}�a��{����|}�ؠ-S�<X���[��bS�Nی��*�O��y�������U��������^�(�!�Y6]t�E}�wtr��\g�=���|0���瞛?Ћ�f�rn�L[&�h�<N�S�}����ߋy~U�5�#���3g6�ԣ��"���>��|�A��b�sկ��X��y��X��굕���3�&�<31��W��Y;��Q��}BT_�6�)3c�D��G�P/���6��%��~���s��� �%cfd$��|n�(d�`�Miؙ�c�`�vs2֎��d2g��NY� � v��rJ~��tK+ *�j��^LV=U&#��� � �)o�F� ��ӎv� H|p��o|#���K�5X�-��b��e��P�8-L� @�0��O��A֛ 4�[o�5��O����>Qo0��L<�ܘ QZF�h���F�}%�������&���?�xc;��bx�pll���;i�=�LGuT���z/6]�ͨﮢ�� � ��̡ �}�;�6���~�!����:��:�O���v�����`��'�tR��QUD�n����V�`��8QP'�����n��^��[�E;�>���>�����u�����K�o9О�1/bEXU���LY�t�i���c�…���E�9k'u;���'D��lÛ21V�7����euۦ�o ?�~ҷ[�(2�[)�Y;wS�O��$���(�9kG�|�F>9��D5_ �͞=�q�>/+e��`n{�jR�f�q~�A���$�PEf��*q{P�s������$���k���L�MX ��K9� GU9р�x���[��� k|<س'�7��#�NY�Q�Q�W>���cRc���z� nVy��,~�M�-�����m�ɪ]_��zh�.u���1�#�/g�?�?�|��`@�R���\�M'���N�J����'��u+29��p�:e���>)?�0���9�?V�����>�(�4�6=�؇"|u����C=�����{�g氄!,��ڧ���l_~��\�����xw� m��oV<1͙3����O�_~��-t�s�?�����ɧ������1�[�ޭ|��:m�ν��Ľ1Q����[{�s.���m��y8��y������o�DX�L���v�[�Ud�Q>��y׬�#��n��m& h��\�2i�a��S��tS��?�'ڍ�5eY`�M����m��<���0��U���� H��e]��7��'J3�c�<��o���Ӌ4D�휯�G�&�E�hy��)�M���'}��V��`e]d���,ڕ�v� ʄq��#�'�p°:�����[n53ֹ���$�6�V��k>�u� WwL��҆�&"V�,.�7��x��K잖�SV��8�ʏ��ײ�ؘQ&��Dm���KG���C{�[;�x�ߗ�4Di2X���*W�m�z@_imf��;g��M��mꋍC�ߗ��Z���G��+�����K��+׷6���>1V�:�5x���d�%�S�o�Ѽ�u��:�}�ᇍ�)?;��g�}vT��u��Ɗʔ�~n̷��x6�t�s�O� �2�0���� �dz��c˴Z��xP�m �+�C;�(���A�"#E�s+Eq k���ut���h�i�����hc�2�l��E�I�����A*����L�y�"<_Q�VZ{� �s��J���e@a@}��r���k��`���&�t���t9�����o}+B|]��p �f`�Q9y����������-e����2��M��@������_5���5�:x�����\��O?ͦ#{c���C:��Ъ<������y��,��C& ��.2۹.uۗi&���' ��!L���0���+6��p�:��X���=��s��k�ܧ�;,�C��S��l�Q=�UڴQ���s���%˟�k`ғ�3����.�^q-?A7� ��zI��A��8F���0��/����3S��m�� �&�j+[ڌ�m7�-���6��+�6�8����j,�{K=���>��Z�g <d�@F��\���20��u�f�q��7V�zYմ��H���j� ��aO�<�r�������ʂ��nc��ed�}�fm�� ���+e��8SnMRw[3Z���|K���?�!_�1��O[ c� 3ϰ��>\�[>e�[�y~�m�hY��lꔿ�]X����r�˸��Ø _��� >�c����7�,nΡLI+��7eBu� WgL��\��V ǽ�U�[�\Z�_�ꔗ_�`m���-���|�sOU� .?�u<���{˽���s�6���a0c�"����Ɉ����{��C�~�ԝ�Z��󁐯۾�SV�w�{��[�������m�xJ��kن�k�"# ��>��U>��C �=�0�gn_�S;�F���\��Ɗ� �9��69�����[�� g�/�\��z�Yک��_��r>������s8�6���n���Fh�� ��)2�Qd<�R�v S�6);)n&� Qvt~�Cnj��C�=TZ'm����l�0��O�@TE4������(� U�5ap��+�&LXIi3����L�]��T�\\(k���z��1!�O�����,�;����ذ��&�'�P7^�L�[�����ʓ��8(�[ݶ��O����ᘐ31���a��% ����Ã�dM:�C�<l��?a��:ܪN�nX-�$�x�Օ\����M,��"���Q�᲎Y���F`}����[���.�F`uȾ�G���G�d��[��Uy�&�����C���r����Y�-�I���Ѝ|�j�ͺ� ��_Y���-�8���mk��w�R��Q����2� ����|S�����æ�'m��*�c��ӔO�=���̊W�sy��1�~k�ʷ�0��g̥��� ��}��g�XY�O��`ƌ�5XY�XA�1��I+�wG�xIهf �6.�)(��y��9A�f�����M�j����]�ظQ�u��,}����s�[��\� >��0,no�i��Q���µ�����CS괭���N��FR'�̿�ܕ��I�3����0Q��:�WR�S��j�����p_��e��};˸{M�9��m�`V�cSt?�ʎ2���f�2��kԆm�hm�����G�x�Y־5�s��'��:��P�K��yq�����X�9���G��7K�O؇�6'=�k�s #�Y�,������]/��6���s�X|H^�Cd$��xn�(d�@�t ��/;)K?���#��"�I���s�OV�|�S��|�A0�HF4����^Iym��I+_���V���V�驺�}�\=e\���a0� ����)5J���o�a����10����D�&&6�('P ��o�G�F���,���$�r"�\�^G��r�p��=�[��o���40ɍ�^��I�Ĩ�hR��_�Qu?�ꔇ��������?�G�Y=�>���31�tV�k���DY�,������_U~�m�ʯ�d�O������'���µʯ�s�U_ e�/_���5�̷��N۬{����E}iս�^b@��,ס�"����}9�����1X�MUX��:���~}�*�U���r�\}6���mж�#�������VT���Y�#�ޜ��ʠ�����<(���N�@�΋�<�x�z��0߉�g>G��9�U��vUb�� ���W^��k�ǔ�����F��� �K���W�?���i۴q�gT/���•cBUAy�~�����ex������sU��T���Ok���^D��O'����������X����ʸ{M�9kU��yΗ��UeG���C�u2^�D��� [:��ޓ���#~�cʅ�3�����5�9���h�U2�cEI���<p=Ƒ�1�\�mm��y�ݵ�K����^���'�� �mS�nC��7�l�I�v�(2�[)�Y;�)]��ίnGg�����/P>�dP朲���>./ҁ���X�kA�`��Igm"�l��A� _�)�Χ��zV��`�Q�nl�R�'t��0���6A`�SU�ͱ�X��}���JrV��� �F�}M����a���=�w�d�����ʳ�p�ꪽ���U�+�1q���K^[�T�g��!��2�IJYp���9jo����R�1�`��|�n��gi��פ���u�ڋ�*�v���9�g����g�͌�����x�W����O��������N�-FO��Y�^AU���yս��f|����JƦ믿~��P#�ޗ��u���2�.ס�����h���QV1f��8TNV}�'OUy�*7;n��y>�R���+���W�i��o����p`f,�1{���?�S�Kc��A��3 3������딏������>��j�mT^%u˿*�vܗO �������=�V�WU./���C� �����E���z�T���V�U�����{���@���Z���e�*�FU�(���z~0#���z��kr��uU����i�pQ����s֪:R�[(� �ʎr(����u2^�D��� � ���/F&�I;�qM�xc�1�LU�̤� c�y��f\�h�U2�cEIս.���{f ��8�jKv��ժ�Q��r�/��u���6��&�i���}��U;��dϭŁ�Ȕ�A��A����:��„�O�x�c �:[��O|1�|'m�1o}|&V������v��yЊ�U5�e&�~@"���5�t��i58A����Y���tU=��O � �L��6eN���C����B Q�U����k0�`r��I_�n0y� G�n,{J��YU8��W�pVw�<19��ץ�,Y��^5��w��!�VQ����� ����}���ҏX}�Vq�h��^�m��SUu�ڋ�*�v���>h;�-��g_ �����3�����o���� �%<�8�&Z8˟?F�o1z�ͺ� ��LTϫ�-p~�Z���QX������Zu�>�VG�=��`Kh�E�5��:�s�t��F��o> �a��-V幪�츕�UM��SU\�}$>ߦ�7���R�G���Eؤ��o%QTձ�w|�Ƹȵ�}�S>�燲���>��jcoy^D��ʳ��SR5nx���@̅�iJS���Ш��L_T/ �g��*��r��.��u,�ty>��̏����/�V�7��D�' a9� ʓr�����e!��V屪���f�� �����%u�Uu���ݏ��������xUU_��0P�I��ڹ���R��'~��g��0��XL?�*g�G����V�D�%U��$�'@�yV�)͏�UZ�:_��5uۦ݄���A���V�$2�Qd<�R�v S�Q�t���Wn\���S��r��`�|�1�ʁ�ѵ�#`�c���e�:k�t饗6�ň*w��d�鉮���r���zT��l"���.q��^�r� `�ģ�:j���Yu?;!Z�Y/�>J0;1=�䨪<�������ʆ�Z�� ��_���q���B�>�6��!���U���u:!�D���;s�� h�G4�d2�J��uن�:��x�2�V',U����K�d�A�{.˖�.����y18��5�L�Ǘ��|m��n�[��N۬{����E}iս��/3B�T��ט�徝����,`�(�����#?�ه,6~҆�A��[+�w����sU��q+7�0�˴{��ވ�#��m��s�Vm��0u��,O�tF�Vz�2��c���7Iʲ�S>P滪ϳ�F�c��պ�_�g;^����q�cu��i����rl��'T� �}���)�kW�mƔ�3�@|�?� gǭ �n�k��[�/���@y���ʗ�*L�~��s���VeDRO���Ve�U�8J�Ay�N��pm�o�L\����ԝ�V����Bt?�ʎ2+��Y[o7^ED��Uk�|;�{eyfNN_B���L3y!<Ͻ�O�u�vMU���^�d"NJ�G~1�˹�m�r)��L�v��HW��츕%��GPU/��?�Em�W�m�Bt�S�y+�6�(2�[)�Y;�)]����� �`�>m��N��l��1��bX��q�3|��|p}���G<Xx�k����`��Ư��<꬙@�P�J��b�k4�$�S58�?����X��`�ŌC�1b`�DqV�Ϻ0�����?lP����u���3ʊ�� Nt���p��� ��Fx&�@�`�Ư�U}�g��!6!���C��[�U�g�M����$�/�~���M6qfR�˞kS���+�0c|]�<�{]�)�߫�C�e����KIk���7 ���mU�qx̓��C��-������n�[��N۬{�����R����?��oF� m�\����S�:W~�ڴ7Y � <��= Z>����`��G�AUDU}�*7;n���k�)�D��(�7k֬|��߲~��G���4����9�A��# GB_�=��1���0z��DePU�"0&H㷾���u��|s�|]!?����Z�Q]$M��[�Uy��e�0V���#�om��I�ה����C�>�r���}��o>��r�X����i�zѮ?���qkC���Z�׋:����_�� ?_���˶*_�;�)�x�|�s�o3�5��{D�1�x��qU�F�?�̴p��|��L٧L�:,� ��vݏ������Guǫ����j��=�y���a}�]o��v W3���B�*#�6`��*!/5VD����w��e�L>9�x���ay��ڝ��ʵ��j�zI����T��^Q�m �M���]�[l'�����Ǒ��"㹕�8����5(;?�� 6 Pt� �t�t����l���:G_>f3ٹ��sEbb�-��2l0�D����/�v�E���?�U� .䗲`[��bh{#��!��������t�F� 68�@K���Fl�`fTM��V�D���vi�Ag��Yפ�.���<وʽU��?�x.���g���o��v�1� ��Yy�y)���x9y��x)'Z��! ���d�Nbm%�g`�T?gbM];��s��:���x��P/�`�O�xh�5_���2�v�a#�+�&��c�Q�� <����N�d��/⧟��k�Um֎��/텸�zl�D�&�U�S�qܷk��= ��F�V[m��m���x7�-�S�mֽW`�o�Plu`4�=�^Ц���ښo�\�vis�:�R��ሇ�+��2Om<���G�d�z���"��i?v��R\�t�Vb�f��K��s՘eǭ�QD���!M�1�A�m͚59��{��" &&����t�6m��c�C��v�|�2~�);�W0�1cDe`uɧ-:���w�T��u˧�7�N|�5�����6�o�Z����9�W���<����5hW~�e�s��u���GW�v�>��R��9FT����ʔ�����=��?��zA�V�AT���6T�g� >>���o��>(�}��v���I��l-��>ܧR�hܯ�󞲎WA��Y�&c�}�ݗE>��0�9V����2�=ڏ�[���P�?���IY��{u� ����;�3���<�_����_��W#~X�ꌋ`u��^����=��v/�ʮn�u|��n��}u۶8����ڰa�#���r��%���F[p���V�!f'��DZb�ʕٓ`^b���ε���`��i���{���E��xkw�/;nu����#�� �u��R��g��e����h��l���u�7��Q�m �k������xd$��xn�(d�@�t �ί�g�����Ą�I���'>U��AGI|e�08��mכ6mZ�! ѵl02&,�I4��!���u��f�f'L>�����}�G:=�`XBzH#i|O=��/���'�U��54Ì��=��"�dDq����%OL�ʽ]������0��a��C9�e�/'/u�k9���[U^&���C�j(�����VЏ��Ҏ�L>��S�l[�W�}[M�$��L�p��+��9s�dӜ:C�FG������0A�a���C=�N��V�Y;^�_�$ퟺe�<,3�$�U�S�qܷ�(?�������pĤ5����5ߢu���� ���$���V����!c[AP��/�!ڒ���������Q��A��F{�/�C��Ȍ��ʲ������|����c?H:H�"}��U���F�+���y%�՗i����,O;��a��t�m::Â{�<�&� KzH�3� ��8�� �:�k`�����uʧ̷�y�v���ޓ/Ɨ�R�|}�/���C��� vܗ��nle)P��<$����zP��(�c��Ж�'eA���1�μ�]���e��q��iU���'l���|�_η�������O�#Y=�;��v< �Ld�$��-����}Q��-j�u���]>�x*߲X�bESҮ��rŀ���,i%��}~p��N�X�ꌋP�nx]��=�ʗ0��aTv��G��+� ����k�6l�=-��aQ �+�H���F�Vz����ɵ�q�`B��CZ����6w ���Q�8�?�ZQ��Vne?h�)����acС���zKsz�����=��;��|ؽ���_�/�x4�m�B�k'��v�(2�[)�Y;�PSz"�T�1PB��C:��VY�N!��D�ͪ��n�(�~+ {�Vs����l�^�F�h1�� ��\�|+��N�e�+0g0v0�:�&Z?�9� ���tc�f��Z'��W��b�笽ꏪ�k��p���"&�M&�m Q��HF�Θ�ϑŁ�Ȕ}�Liя�iͳ�>;������r���d"��d4���c{ �[�� 2�'���?`u#ߘ����G(� �y�UW�뭾Y� �[�U��g�r�'zΪ��;h�����)D"#͘� 4�#6�Y;�)-��ҢQR `�_}�o�/��c���uʱ�(D;&�mʔ���C��g��F ����5~~��zK�����o�����c�=��A����O�o[3L��U����X��2�mS�:DF2����Ѐ�D�(d�@���[dJ�~D}Hk��m_;�ߦ�`"ۦLi� |{��0����@F�ij1�~�h�_1�=?Xg�#�O/�L���3L��U����X��2�mS�:DF���j�V������B��C��O�6�B�!4. џ�m��@d$�/_�Ҙ�=�D皬ȔB�P"D��)�B �qQ��DmSL"#��s`@󃆈�[m��e�@��Bt��!��M!�b��B�'j�b2�ݔ���B��C��O�6�B�!4. џ�m��@d$wS�dJ !D��?Q�B!�и(D��)&���MY;�)-��>D��DmS!�B���ڦ� DFr7e�@��Bt��!��M!�b��B�'j�b2�ݔ���B��C��O�6�B�!4. џ�m��@d$wS�F��o��A�͍Y���U���K}�$���6%I�$iH%�?��)��"#����0�7��K�4�����ڦ$I�$ I�$���6�~Vd$wSv�Mn��� !�hQ"D��)�B �qQ��DmS�;���Mm��4�S1߅�G}���ڦB1��E!��M1���n�6��C�B��C��O�6�B�!4. џ�m��@d$wS�dJ !D��?Q�B!�и(D��)&���MY;�)-��>D��DmS!�B���ڦ� DFr7e�@��Bt��!��M!�b��B�'j�b2�ݔ���B��C��O�6�B�!4. џ�m��@d$wS�dJ !D��?Q�B!�и(D��)&���MY;�)-��>D��DmS!�B���ڦ� DFr7e�@��Bt��!��M!�b��B�'j�b2�ݔ���BL�{����|%�mł �����t�m�5��n�>D���N�����!����brR��/��2�|�����N6lh�>��t����|�;y��f�m���y�����w�u�Yi�]vIo��v�H��T�QݹX]�g�;����u[�1VL4��U���j�k��� /��8�[�M!&��HL�)�~��t��7'�[o�u�:uj���!zG'�\�|y:蠃�׾���կ~5��Ls��i�;�y�R'� �?����w���4w����!8�{��rJ~��Cp�]vو4��*ΪI �����vO������f�ajeS�����p� ���F�9sf��H����y�w {���;�0�L���b�-r8��Ww�8S����W�L� ��k��&}��'�7u���J�zh{��~{��׿���z"��/Ҵi�r�f}ݮ�z���h� �����f:��r�*D/��6�2n����K�o�}�k�Wp�y,��&bN6Z��hs��u��5B���Q��\�.�۔)S����ӝwޙ��n�q�c2�{��O?�v�y�v���s����)�|��5�}���V�\�|�B���o�A4����vBy�����t~���N<�@�� ���'��M���{�qt��;g�vݞ|}�uз�M�MŔ��NƪY�f�~�g��n����|�s�N;��}氧�zj7=����n������<,���S������s��F�E]��D�S��sٲe�����NO<�D���GL�0���𗼔�t�p���@���?ґy�9M�͎����&�Tı������i�|��Ӆ^�}��t�g掝{m�|�A>�����3�Vfo��F?�0ad�H��9��(�U��o�1�� /�뮻�y���>_L�(²�ʌ^��z���J7�tS��K����{Pw�8S�Nz����ݧ�� .�y����!܃Ҕ�����\ﯼ�� //�O��A~衇6�:�}�h�)_��|�Y����s߇ �M��N�ͪ��n�K����t��G�'`���'?�}�1�}�>s����}��@��:����OVV�L[�L���=��^r�%y��v��)=�y`�x��kt�R{��}������_�:_���`�%�k,��9F�h��C�w�q��ɇ�� �@�7Lu笝�����>���P��M�MŔ��~��M!� � ��X�i^c/�����oZ��H��)͠΄�OZ0�d}�m���*����C+���o����g�>�����`��������mGKX&�L�P7:5����l�c>�^=�\mRXN^�nN�� �r�'����t[ ��hP�;�a����k��ʊru6u���/��R>Vw�8�2�$��I���Yz��[����ۇP�e�<��3}e���k~U��S��ʁN���Ξ=;�!�W!�M���ɸY�7��{�;3'�~,���/�Fu;�[DcF�x��FK'����S�{�w�{���J[a4�w' ��֘��n������������=��}C�g��D�[<O0׬Z$� >h�#?��OG<���(޷�u�����`�o:�-���z����}M�t��s�N�v���C�P�W(���D��M9?�籪n���D^�3�}���EFr7e�`\M�VCd��:����O��!�����7�N�XM꿊U7�������1{Xm��O`�����Ty@23�c~��M*� � E�����&*�aˉ�M��:�r��_���=� `E�����n�̃5_!f��5��i�di=��ӆm'A8ʙ������m�m���|��$�xʯ�׈��س�j�|��UM�r�5_��y�+�|����[�(�:H��n�ĭ���k�0ez��<�k��u�#�q�7٨�WRf�2��Ư<���7P^��ZS7}8V83p����aʾ�Sփ&� � mݾ�C=�������f�8�onP�I{�w!�P�m�q�q�q���o���Sǭ�R�M���<��ǭ��9|[ȏG��r�)�6��-�H��igQ;�/(���� ��a��~�_�������A��ZQhy�\~��8�>x8���0�-��\%�wH��e��E�g|��7��j���'�i�u,�Gq̶h>Q.ܨS>e�Iq37�cy+�ي�"�+?�hW�u�U+(��<�{� ' ��@�i+>��V3�+)Ko`V��� �ֺ����i�]�Ϭ���]��[��V�,.�7�9�:���i�e�y��3 ԭ����_���G���w�[(w�S�7����3'�yk {�����i����ŋӖ[n��7(;���%� k�<�����r �I��B�/ �6u�uʡ��C�q+�N��v�+�)g�������0��{�X��<��^�g�#'�ൺkP�Y�]�]��{��gGu-_��i���S��~�����<�c??�zA�z�f:�c˴Z��xP�m �Mh�^z����C�,\d$wS�����������'���w 7����I_�$���Ry:Vږv�^�rA�!MڬC%^��Ɗ�E����V���p����h�6y`��d-���䍮oP���m� �ya%�:XZ9Ƅ��-a�����;l�q&�L�=4:Lz�a��h����{�F��ʤU����z���4�ze�� ʃ+� a��*��D�\�A~) 3;I�M���H��|��c���M(��&#u�J������x�}&Z�����������}�����v}�a���_`�F_h�m��(����`i��_#2�� Sw�^G_!�uڦ��6F�D{c����>Z��[��|k�׌ �}��r[�/� �n<����s�vd�eط�hk�0[�ҼWw�L�}} �~�k���W� ��LY���o}��ed��}�g_紐������w�ʭIl���{�|�:`�m����2��!��C�.��ձ�yDs��������[>���8K�e�Hݠ�p����_��.�o��)�s�v� ���ݏ~��|ˏy�"�6���vk���P���eqse��b� ���,糀���� ��u�Є�,��{T�o�riu~�ߗ���3J���{���xom�o}a[��m>�_���u��G�a����:Ji�>���k�=�� _����#�-�#��ʣ�ԝ��)D����ߣ��\ϗ�Ȉ�����Gu�+�G��lD�5j�ԕ�~�F��W�S��\�x�S��{�+��l�<�F���\��Ɗ�:����<7��/�[�y��~di�R��:���C|��<�6���n�b<0?���"#���v�������u�i�cdJӁ��|]�u�~�A��W~� ��<�D9/*�h���:T?A7lp`Bʪ(�|�Ͱ��8=e�]e>�5�V�1����i�~I[�ki-Wg���� B�%+�<4>&�f�qM�r"^��2Q�xX�8�y�ĶD�۞T�W&�C���f���c��jewUz�'�,��%Kr�^ʎ�E���=����+)O���_Γ/�Ni0e�qY/�_d� Vn���f��#�q��[ ��Q?a��_�L�ߖ�� y�MRwx����)���olN}�.uڦ���Co�P?io�E#���j<�m{H�=�.��A֎[}�k_�Ud�]>H-��ǃ"c��'� �>��~�Hʇ�ޏ7%c��|�>�q� q�O:�|oH��`�}�6W)�ҁi0cƌ���x����  O{��q����G��Uͣ�z�o��>����������1�$~������M_�u�~��<�iW%�����l�b鳹K�/���6ѭ���hk67�����&o��,\��5�+�m�����m��"�:9��Iy���v�(u믙��Vgr�믿>���Hʊ2+�I��m���]��u�{�n~M�1���k������`�!X��:qPν\�Uw�Z� ��Y��v\�?�xeX9��5jö����9�c�>���s�=+q}?A��3߇r���v�G{-O?�u곥ӧ �熪�����h~d��/��#^�mbk��M!z�=�G �"#���v0ᦴ�P�Ǫ�:����?dt�~��k:�H���<�\y���c����hЪCerG�=�l0�{9�0�����Ǯ�et}`�b�Wn; �V�U���-W��q_66A�G���� XU^�|�k_L�s�r�� B&�f�AY����i� �=�[�� |��Ͳ����b�������Ze>&u�Jʀ��/~��uC����V��|6��Y[��Ue��Ѷ�L���(Wlq��ab��r5UDY���C����@��J(���a���#�\ h{��:�C����:�W��� V>��C#� 1�[a鷶z��g����X�`�5�S�ʄ�d~UD��t���(}3�����=��ʠ�����cؚ�Fy0�ۃs��2?�G9S��� 3H��t�QjƦ��_��]��k��|�W^�_��L�h^h�w�ny�(��c%y�\��T�Mۦ�[>�zeP�ʝ�AUAy�~������(�����ש��� /d�����'�|�Y��{���">��(˨�WQuO��5PV����G�H��gK�����/�k��zA�9k'�@�m�����:�J��ZՆ-�f�R?� c������1�B�-u�8��֮a�yk{��V�D�%u�s�熪~�t��:��͏��%�?���@���6���9w����+� �ݔ�� 5���̀+'���N>�:G(;p^3��/_K�b"mTu���A���`��O�!�h�:T[}뿎c�:i0,�Q� e����]èz��e����c�A��׎���S\��Sb&2��V���z��� ��}��(�p]��U�������3I#N&R6�&=6��$��&`L̘l�A����V(�+�2���}%��{�'��O�¼��L|���XU�����Ͳ�TQuO��|{�5y����l|]�� �^��1mڴ�5b���������6�q�o�F�z�Ū�8�?����U;������W�_C�0C������}�2��C��!�4�s ��f�m�`�x[)���*�U�fǭ�8��Y�pUqE����>���� 󁘏ۇ�o��o�D�8"*�(mf�7�`���n�_��p>?�eF�y,�f�E�UR����l�}���)����3��*��r�xY�?l��Pw���^\����pv�ʽ��1�\�=��| ��v@��v�(�kV��Bz�m[���|Hd��V�C��̐dnZ�g�t}{�^�.�1��k1��}+7�'��<������o��;g�����*�ܳ�|�:n�Q'�UIT_��0PG�!��W“v��\��d�}� �y�T��F3���}͸��\��z4�cEI���������1�"}e��㾮V͏Z���}���{Mݶ)D���d�϶6�A����� 2��)kfJ��2�) �^S'� ~Ń�\�\ա�T��x�a�!�1���/;ɨ���P����J��[ޫ�2~�V_9f`��>m�l,_<�3��e��|ۍA����Db���Ǣ{e�T���\���\͐暔�=e���Z\�k�D���D�竓�ru����d�İ�_�D$����}%�I�0�>�ç| +���+��/����u��xt k?\��o�YL:�+�U��s��4���Vf�q.��>ChժU����I!�Q�m��R�mv܏'Q�Q[��T�G���j!,�OY��C,��j������=��s<�1���q�d]�ti#D }<}=ci���R+C����������XqUWt�~�|cJ�/)e�q�vA��1���rU[�AU+�{Ƕ�4����X�|,��7e� �֍͔����4���́|������E���z�4�y�b�hht�:9�6�A�/�O�g�Ԯ�ڷ�0?0H���\���7����b\ˮ�|ŗEU��/����:bu��ų�_�ڪ����s�N�!�;��H9E���7>G3^U�ת6 �u�ij ���KZ�.m�ga�S`f0��������*g�G��\Fs���+J��稞��� v=�{�ڽ�u5�A���u�|�k�M!�[�Q���HL�)MgT�"����'�������D��C/� ���f��&i��|h�:ڨC�<�W��fq2�/W]����r>ծz �p¬����ll�Q5�0�:�7�`�f9�3��g@z��Fd��y ʈpQ�����9��+���D׶�dr�ʷ�\;I/a����^PVQ8�V���Dݾ2*+>��_Ud�z��:PuO8M �`W�3&vLrmp�0+�5�ɲP5���M<���[=)����6�P�O��a���#�7Pϩ��Z[���V�}�����r�L <���n��������A$��ɰ�ӗWQ��r��Vn�)�1e�=��A��ht�~�j��(o���B�|�%QTձʀ���OeY�)(�]5&�yg��4� �&��u˿*�v��#K�.��a��cJ�l ��j�c��ј\�S�Ϩ^����*��6d <"�������Էr_V��R��V���*ﱇz��ඏ��惇x�=����.������w�#�1w!��~�QG {����\��kig��� �M�9k'����m��=�?�|�WQ}mՆ��+{'�-���i"�2���^zi3��7���ԍ�N��Z%ԭ�+J���o1�熪~�t�>���V��'�AU��2����^Q�m �Mؖ�ܞ�ڊ�].2��)k�nJ�q<��y�� D�I�|b���}������*��A�L��Uf|�IV��F*�}-׋k3Ie`!��gv�W� ]��+&�m�nO[�����5�����j����Q_Gx@b�±�bL`���M��&�ހg�eK�X��)3ʮ��5i��h_����+��׫�k�����O��O#&i���&��Ê���Q�P��|�QU擁�}e�� P|�@ݶ�����"�o2���믿ެUu �p�|h(�~����~�~h��i�,��������a� ��ײN ъ:m��Ŏ��o�ڢ���yl�`p��S�}{�ƨ��W��a�xjЯD:�à哼E�=�4�iFO�X�`V_�w`4�=D)?��Yy���l|����w�>��E ��X8�?��ُ���S4��� ��X�*i�ַ�5⁺N�@�o+֧s��&X�Q]$M��[�Uy��e�0.���#�om��8��[�1��6/��'P.u�J�͏�Y9y,�r��2mV/��Q�;nm�8������)�r�j���/���N���������[W�C��%�~�xx���#�����U���Q}�ٕ�"ڊ����[�3���_O���?kt��s�Nʡ�s������Guǫ����j�@}�@�>�+{��n��֜�z�$/�/��7QY'F{��2QcED����u�����/;nu�kUm�b��� � ��S�zEݶ)D7����k`~B�i�Z��H��)m�"��o� @�J�+���&�|m���0��вS�����o�d�J�>7���q?@����~��qX��������I*(�|�w�}y��{�! 5� /�0��m�B<��4F���&�6Ȓ����z<Če�<��z3��V�ؠi��&#���s���_��*_ą)k��<�=��S�zc�����k��5��� �L�|��r'�e�H= <�֓F&��)��5eE�w��I8�#e�)��@[=��#��%V���s+/��-�ܒ'�Uu��:�}K��'� i��"��^�J��kO�\���h����� ,}(�2C�8i��y�gf#����FuR�*��h�;���7YGhc�=h�I{��IQo�� ���·uk�~�>��K�p�o�X���;�3Hc(�±W+m�α��߮I�/���>H���~�4�O0�Pnk֬����a3ɇ�����yv�8F�J_j�ȇ���[�g�������O[t.p���\�4��O�oʝ�(k���W���鼦��Z�p�I�W���<����5hW~��=`L�Ok;~^A\e�a��<����Aݱ��)kqsM�i�2���`����������m�k��lu��U�V��>�%�<�X�jW��ʉp�O��5?B��!a9�<��%��cu�8�s�~Ӷ���/���=D+@)k�+�Oe�\�8���]2/�|Rf,�կ~��P�=��,�g���;Sk{��Y;)��η-�q��G�e���x��U�u|�������n��U��Vm��[��q���)�o +�����z`�.�CT'��k��X�r�����k�u�s�熪~��\����#�� �u��R��g��e� �i��l��u�7��Q�m �M��������-\d$wS��ݔ�á�W���v�N�I'̧h�4:.n���az���%h��0�3�+�~6lBf�u�����U�=?+���1Q8���G�߰b�Gx>ɥ��mvI��?z����������}�P~��c�b�>�&M�_~y3����nh�/[]�`�� a��JV7��+���ݗ�k�GV�������1��pe�kꀇ���j��u�����d�nBy�{�}�Ι�����ၜ��`H���¡�T]��~�Y�s��u�W�u������N;�Լ��ck�F��[�<<�6Փ�_~9?x�+��hE����`��xB��Y>p�n�z��&�,�r���#Ƽ�S�6�-��r�P�mևZ_@�<������o���>�Ã�o�ۜ~�W�6X�ߤ����V�e 6�>%O(C�j�c�=��ӆ�G�Q�y�y�So�D�-qa���ATǢs ����O�o�����U���R�|}�/��*<hW�Q�����aG���>��*c����z�ἢ����Xis���1���=��C9}6na��vh��]���e��qK��߂v�6�:}F�:����'q�IS4�1�y�Po|f�s ��ڄ�0�e������:�/f<�u�/��ʜ亴C�k)�X>9��c�y7�!�;���9 ˛n�)��C�9k'�YG�(�c�9��M _��~�EJ�I�n����wp_!���ڰa�Q�� ��I_Y@:xn,����Q��N�Տc�x�o������s|�����~ЎSnU�#�� �a�Y:X����!>޳�A�-�&ɇ�k��=�.GCݶ)D����s�=��@����{�ݔ�� ��ÉbS��DC'��c�����?� &>a��� V~3ь&{��!B�'�6����<x��4�A,Z�%&<貲�{�ձ`F�7�D=0�X�������W07d�ȃ)&��8��9k�����ڭ6�oh����G���n�B�!2��)k2�EOa%V&��þ�W��&O|�o_��@V� �,��?�ȶ9M(1�ط�ڭ�������/L��U�Qw�X��1�mS�:DFr7e�@��1���w��A� _9d?C�k{$�52�V~�k��>D��d"ۦL(� l`{��m2��-d4L<�D�0�sV�GcCc���D�M!��ݔ���Bl�`����D/a��/9�� �d6�A}���D�M�P����b2���z4�h�x��~a���ƆƊ���n�B�!2��)k2���ԇџ�m !�Ch\�?Q����HȔB�P"D��)�B �qQ��DmSL"#���v SZ!:@}���ڦB1��E!��M1���n�ځLi!���!B�'j�B!���O�6�d 2��)k2���ԇџ�m !�Ch\�?Q����HȔB�P"D��)�B �qQ��DmSL"#���v SZ!:@}���ڦB1��E!��M1���n���S��w>h��1 6��J��}�����ڦ$I�$ I�$���6�~Vd$wSv����"5~I��"�!�ԟR۔$I��!i\����ڦ�ϊ��nʮ��m�4~!�-�C��O�6�B�!4. џ�m�~'2���M֔��o*�����?Q�B!�и(D��)&���M��~�P!:@}���ڦB1��E!��M1���n�ځLi!���!B�'j�B!���O�6�d 2��)k2���ԇџ�m !�Ch\�?Q����HȔB�P"D��)�B �qQ��DmSL"#���v SZ!:@}���ڦB1��E!��M1���n�ځLi!���!B�'j�B!���O�6�d 2��)k2���ԇџ�m !�Ch\�?Q����HȔB�P"D��)�B �qQ��DmSL"#���v SZLj�{����|%��+W�Lp@��{G6n>���t�!�d�ɦڇ�n�~�N�T=�8(��_~�n���t��� 64B�}�Q����w��<�f�m���y�����w�u�Yi�]vIo��v�H��T�Q���3��p2�� /�_��Wi��ō#���\}��L���uc�Gb$1VL4���W_}5���^���M!&��HL�)�~��tꩧ�o~�y�i���SO=����F��э|���^{-s�1��_l�<l͝;7x���2�a��ԩS�g�}�5����;��T�y֬Y9�2 מ={v��/���կ��}�k頃�f���n���q��#���d�ד�e˖岾馛��g�y&糼�'�|r��{���A���o�x �fR��������`��n�t2����M��}m�����Ҵi�ƥ��&��ߩ�67�z<o޼������(��p� �#���.��i�n�������(�#s�뮻�u��5B�g��R�.�M�2%M�>=�y�i����:&S��<���i�wNk׮�����Mi涧�~z�?��i��7Os��i��7���ܸa�<�ȴp������6�K1�bn�ܜ��ۭ�O�{�'�1��իӎ;��������7�'z>����s���u{"(����̦bJ��Q'm���<�~e<��6��6u�B���H��)���{�v�}����� ��瞛����W��d,���O򄌴ۍ���Me�\�̺����z�g�c���Ұ�w��vK\p�0�I%,a"Ƅ���`���;,O�g�I�9� 8f� d�&;��ۍ�x���i�m�M�^���w�?�TU��_���B$1�Ġ�� ��E%(�p�$2(Ȥ "�0 /���eR�Ax�� ��� ��@T4j�|��>�z��uv��sN���I*���5�����]�__��:$:{�g[|�m�m���$���x�W�㦥O�l�ܭB��&w����|��́�N����־��ԍd���f=��BQ��*���t��G�)c�C<L����<b��vks ���_���s�9g��~L �6������<����l[ �(4̻���1el�;�6^m��(J���4��Ҿ|pe�zjr�Z�1!7����� � =����܊9 El�+�<�Gޜ�o���9��/���]_�\'�4?���E�=�9k�A�s��"}�6��YD�X6?�^����$�Ťz!�1*$���^��Q���I���W��F�I�G!�'�|΁��N.�\�v�i�V-�����x�+{V\^c��I�zXl��9ɜM��&� �(�:��c׵�O�Ӈ�&Q}y��W��>�}�d �ܟĖ'�v"@t��7{��v�:)�H�ȹ[�Z�D*l�d�=/�����񓺑����ǥ�ά�Y-�����_����Xä��'A��;���s��.��}˃�12�?�H^����.�l[ �(4̻��Bo��>���H6J�oM>��<5�W+7�E.Ϳ� xk��[��m|�%�\�������w*L���;����4?���0�y��6g���ј��'D��mx+Sc�ˎϏƠ�%jm3I�F�GW�Pu���<�&;�{Q���i?ib+|f�-����'�z�KI��Jrx]L�}�PKb�w�J2JNy�O���-��FV1�S�P��y�6q}������*>%b����l}�s�k ��59���~�ǵ��M(�kżR�j %��.��]p��q��8�C�b��q�ݬ�����3�<s��"��:�m�����vU�����K!�%���b�lE��+�W0�72A�x����:�`�]-&'E��x���6�$��L�AgJ��w�+�� �aV�����yؗՋSN9�]��xr�c �+u,��~�Yg��)޾���I�!j� V�ٰQ�VA�l�۴�����n/�/��M�X� �������~�r�s��g���f�=6d_urV"��eu�l�6P(�6����_E��[�L�;^%��_]���'�Xٳ���O^�gڍl��6.#k/ b9�s$ ����E��6�?+k�i�R~�5�F��Y_)��<����>竑��7����l� ��� ���.�l�,&ɿƮ�@&�Sq����[��@���^������$ 2`E-�æj�*dI?�#(]�߶���8�~�v5ά��2�� sO6�!ҵ8_��3���hL���EMN��oA.��?�"�X�~�� �v��as��mN� ��uLt͏��k�`�����'�gMmΪ1�f>���s�Ω�G��c�7���H_��0���[�P�o6ڹ��k>�����b˂�� �s�=S�K�c�������!��c9G>�6�K���G� �w�M7�񱾭��y�h�m&��`���-�WTHr�����}����\��-�#����+�E� �)4@�Q��[p/����A��u3�ԣ�@q�'���޾M�w�u�퉅�:���}�������;z��B�D�>�Z1�Ev��Z}�@�%�0���L�8G�c�'�pB+ �e�.$O+ �9�i7�� �$|{~MJ���S��� �7v|"t}���Ĝk#O�����N�U���Nx�f��Y��!� +#@oITm�I�mǂ�f����55�gu�η�؇NqM���_S�8��/�� �m7I3��t ǰ��+�6�$}��M�G㯈-�[bz�$�nbk���g '�{뭷���������'&�\��k�m���x` �?9�Oq����e�-#|�&��(��j�����oDaˤ>�����>���?ߞ�,���S⧕2��P�|lUa?MR�Y�=)/����ܗ|@:f��a��f'�%��)j�Jq��Ozÿ�"]d�������eW](O�ﴗ����+}#�{�y ��"�^�;��S��G��^K��Oa���?�uT��dJ[�s�ܬ��8�G׬|}����/�=��q� cT�[V.]�{(�"/XA��_Q�����OZ86ʡ$3�!�����|}?�� r�@f]�#��Y[-��Vv�6g�M3�bC�����dU�j��c ��'��Ȇ;��H����)F�P�{M;��^�1Ċ�W�_��s>�)v�K���˦��%���lj�l�k����u���o�{?5kjm3I�F�^�:`THr�,�(�� ÑN�$ �P��J..<�g���p �r�r� �BN��a��u!�J�IP��+�k�xq��EI��6��-O�8�s(�����w�$��` ��B�~� ��d]�>�u��.��A�����@����̽h x�*��m����7���]O�������j2��><`�͊o{. �}�O�D�i�䢧�J�63�>�ڄ@6�:!�`#�Bƶ���Ϯ�$�؆�|���W��5^{��v1&��.�6�P�]�}ڍ���ډ/�fA1 I���6�}!F�>F�w��A���lM�5I�&�[P�_V~���������>��66�0��Q�a�4��z�J}f�+9��OB.�?�%�^y�kdA1M�>���V�A����?�d�W�Y�sm^*(o�m���]��b�{�| ��|<�<�\_E���7��j��Ǯ<��//�j�rB�/r]��&d�^nؘߏ��������k�B�&[8��:��A�)��������VG~���@��'~��jrZ{������X�E��6W (�Slѧ�F�J�#�y����v[�̓ڜUc4�|*������%}�l����mq<�OsK`��0�ߦ� M{/�bE��q�]�����\b ��em.!��Hz�ߵz����}�,�����f� �t��^(����d +J������ 8+����gM���*Y�"��唕h�g\8}^㷲Th/AEԤ3j��h[6��B輣W��Đs(ҩ�E���*%���x O�Q5�H��v��@R���ɗ �*����vH���~�J8��-�(�EO��z�ΥM谞���16�/Ƅ$$ҕ�F�A��b�Q��I;r��#%���,�C��9�������F�v+y��C�+IfA�mz=�#������Cw|�����,��8�Ƨt��$��EM�����ݩ��S��I���,��o�i��\�Y�����U��&Ɨ�S�$���4�AI�<�N��<(�i�\#��)� �=}T !?���܊�^+�R�#����d��#�� �rB�h��O@.�����@_)����kc�ظ��xP:Nr�mP��q��V�󁶑�����vٌ�t������߮vgNbrDpN���_�N��_ܛ�/h ��4?���w�-��.?�v[�̓ڜUc��W;�*��Z��<1�ג ��*�����o��1r�;��^�E� O�?�܏8R�1~�w��f&�"ʏJz �����E60+jm3I��8�^(;� �Cn���������ڎ;��:��΂�~�+J|JQ0ȼ���~EE�Az���#G��/m�hL�SR�I}Tp�L lJ�HH�#GO�@"G�G�1�W��'�.�m�6�ɀ�1���\��l���M���"�A2A�ūLv�ɏ�/�"�^v��-�m$wM��O%�mT���'%k��Z_�l�o�el�u�οr�eg��m��z %�f�K 9D'yhf�B���F�vSܢ��X�͠?6&�F��M��B��o-��3� �k{��|;1c��v��}�ݷ���K׽�����f&?�_�D�cE|1�ɷ/�XA�J}.�M�%7γ��Ǖ��#��~P���e�]�\;��䥑 ��E�`@Q��|�Y�W#g��������*�F���ʿ�g�����۟���A�S�U�^I.��r ���!肥tm߾H/��?(���{��>�8�>������:��6��������&�Ή�K��ҩ��1 �m��Q;?�>�� ��'K��Vv�6g���q@��f"9A����G�#}-�0P,Ճ!�/�9�����{r6ݟ�O3��^�E� Oi�=��~����>�l��2�l��u���|�ϳ��6�d^�z��,*$��F�Mi��ɬ��'��M��D#r��pn�U����NYDZ��'N��p�l]�&�O��x�~G)j��%���(k����7[���<��K�Wn��D�?��t�g/�?O�� ����g� I������Z]��I�e�s�_�ܕ�0�⟶�t^+H�HҔ\lvj}ed�7���{i,@��*J�(s>��ku�ċo�Z���n�o`�� �<C�Q���O��$��6� �W�����?������>����X��${���KL���jrlc�eZ�ï��ʹ��6�t�Jr�~ɍ�J�,6bL�?�g� ��(�wI�5���j�/-ȭ&/�dP�1�ƎO9<��S���8��G��� +d��,j�f+J��'Y�F��枥tm߾H/��(M~����?_E2-�Dש�#��*,���ȸ ���c�!�}�*[� ���o`�)�7���{�̏��*st�O5�?kѸDc0Kjs�hl!�h�#9A��4���9M�*�kɆ]�M< ���\��}�M �6��v.4ͽ<����X{J���kq�PE�(?���z��?ϚZ�L�ya녪F��!7��\��8t�J6����ש�b�~F�BBC����}���Wr��S& h��-W����G����2�n���\�@���'6�@A�ď�@�u��H�d��l�E��%��8��z���Ͼ=��؅��D���_f��������Y^�kڡ� @������I��+ ��Ƕt.�G�?����C�$H���_�ݬ����&�=9�ZZ�%$�v�]J:�~;���EЏy�nԶ����@��$�Rc�^�����[��Q�)M�˴R��ű���_�8���i�:Lf�Z[�73�����<��Y��m,�>����E�R~#��*�i;���ʛ��K#�t,�?����E�|���'�+��rY����Z�����^G,jq�"F7�/F�},��Jra����tmQT�R?#��g�A�8� )'� W�}x�_���7�]V���_��c‹ x�ݦP\�s��B/�� ���k�܄1��� �����,zN;�6�*�֢!����vI����ά��Y���h�1/����Y$[��""}��a����آ��b t�6��З�s�i��Yd��п�9��-BEv�J~�v�>��@�%K��GP�K���z� ̊Z�L�!��j��1>+*$��������?2��4Ng��@�������������G>��Ss!��P�$g�C��uʺO�� <�E�EI�0/_&>��{��Y6��k�l��qP�����؞ �����(����*�W�J�&��m���Y�D`f"R ���S�8{$e�$�>(+a� �X� _M;� �L����?+�y͘�"��� �3V��-}���^���J Y�N�!� )l~B�Y��!%�@��y�bV l5�C��5K:�~;����Phܓ{�Zݨmwi���6%���&��{��VK�?�;�T�?ȣ|[�fxP������ȶ6�_E� �ږZ��o��^�-�ܲ�X�F'���&Ɠ��o�"?��j����?k&؂k3F:����4�AI�"(L�Ɲv�i݄�F>������܉�枠�G�H�8�V��>k�����َb%����_�?th��Kdc����q5�ɢk�7 }ۤ��A�?���!�Aﯧ��.��>�#o�<�l��E���AП��cK>Q���P��3؈@��/�"���\McY;?���k3'�m��͋ڜՏ���!���G�#}��a`�) 3���m��^{��nn�̅�����,*VD���9�����C?Α/oKܫ���%��(��S��YQk�I245�B|�JTHr�̵( 8���5�s�z�<C���\�~&8�黊�8j9e'+p���?��\H��S�xn��T���C^k:�c�;S���[��X�|K��� �����\�OK2+>i���9z �����􋄕��+|�c��K��}{H\����5�V �J2�7���x~�� Q2��� �;΁�������|*���N��o�܃�!:���� �ܛ�L��3i����P�CJ6A"IB�� �Z�Ƃ�<�#��m�%�b�K����.����:]�Ս�vc����w\{=��$CPc��.:�}������t衇�z��Țh�mjR�-a��؆����I-q���*ķ_x�mDq��{�3�k"5v���W�e%~�vZy6:�$�R��'�h����ܞ{���Z���Ɖ}�F�uq���_�Kɇ(:p��d ]�m��ƛq�M�8\+�o�Ț�T�D�h���>�d�<ǡ��=�F�Q�A��|�ves�;ʉ����&��q��E���L��'���j���[�����|��c��A�?��ֆ�=K����jΗ>�A�'��׿��<������ �m(�e��襵[=��ܓy�/�y"�.���������2��k�i��j��,�9���,(��6g�^����h>ņ�B��e��`�?�>V?���6����vٰ��EW���hn7�\�Ͻ�+�}��V��Kd��g���E���8F��} U�����������G�&mE��3������ ���苷S����n����$��z!�(*$���^��:��������zV ��Rr������19bp���SO�ছnj�Px��u8����q�������<)ɗc���.�'"J�ģ�>�6���i#��0��MZ}�}��M��O���+ ��t�wl����g�� m��_{���ߔ)D`������(��I��Ѹ��t����\�c~�a��IQc��9W���O^�܏�-��Y�n��f�R�C�lB�����v��� :k��k�t��vl���$�'~����&�v�S�5���W㗒�5����^����_t�nh�4z���]�x�����NH4�b��kq� �� aK�����6�@��D�ľ� ˿M��/�NQcw�c��������.6:��$ �d��G��Σ`���B^M^ʵ�㸆�d�Xt���BۢW�k����8�jwrƞ~�K�1E����/?��r���>��[��0���n@��5i�I'��N��D�-入��~�O+��yפ}�봏v"_r\k�ҋI� ��~oC>'d|}�W�[0�|��>$"�Fv�Γ�C�<����U86/�<`۶m�OcL���>���+��+��Vl��6�H�K�����"�'{챶�%�vy����"1�+���ڜ5#�ơ4�z��'�� >�}�Ѥx�|����u� ���� oѾh�h�4s�>�c� ��aL��C�.�QAJ~Pr�~��R)?���?�-ԫ̃���s���x`o��G?46�S��n��i���$�~�^��G��!7��B�ҋd��sY (��Lf A��S�|pLH�$�d��Y�T P&��S��E>�偉.+�K_�l)��"+�j엘�?�����LR)�E��M2~������u(+b��hYX�m&I Q!y�Mv�E�d��5%��c^���*QiӫgIbI�$�d����E�d����V��!�ҋg��VQ�O$�f�9k��a�X��X�m&I Q!y�Mv�E�d!P���'}�2I�D��$'���,J'}�;���'���O'm�,4,����n>����(��W���d�,:gM�12Vl^m�IRCTHr�dQ:Y���|�*��d�H�$�d���E����;)2�o[A�f�|7���N�m��6���%ӳ�5����X�yY�m&I Q!y�Mv�E�$I��I�q���$I�$�d\L�q���,Q!y�Mv�E�$I��I�q���$I�$�d\L�q���,Q!y�Mv�E�$I��I�q���$I�$�d\L�q���,Q!y�Mv�E�$I��I�q���$I�$�d\L�q���,Q!y�Mv�E�$I��I�q���$I�$�d\L�q���,Q!y�Mv�E�$I��I�q���$I�$�d\L�q���,Q!y�Mv�E�$I��I�q���$I�$�d\L�q���,Q!y�Mv�E�$I��I�q���$I�$�d\L�q���,Q!y�Mv��(��˯l��f�`��5��r~K�[n���6s�-��r�mu˸�[n���6s����t�uE魲���[n�҇��8����r�-��r[�2.��8����ƼE��!7�g�}�0�$I�iI�$�$m3I�$IVɸ�$�$m3;Q!y�m��1��R|O�dx҇$�8I�L�$I�U2.&�8I�L����<� ��:L�$�A��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���d?�'��I�$դI�q���$I�$�d\L�q���,Q!y�Mv@Q����(�$IRE��$'i�I�$I�J��$'i��2���dY�N����6���'�뮻ne�ƹ��{�7�� ��I��,������|��l;������d���m>��O��OC�m�Xm�8.����/i�=���mo{[������g>��{��^���s���/}���>м��K+{f�V����Yƌ�c �d��9W��,"V,�>��?�i�|�����W�̖Z�L�E���d /J���o�=�ع��~2����x��͛����o|c�я~����ķ�����r�����/~Ѽ��h7�? �?���n����Yg�ռ�� ���'?�����h��ַ6���wV�������ӟ����׿n����6�_~���a o��V>� �Xl�����y�{��޳4Y{���vء��7����ɖ{tm�J�u��I��ckt�τ�_��W�m۶���~��l���w}�^� ݸ�⋛���o�qj_t���6���+'�l��~�k_�Z���V�XN"}D�9��'?�����j�fl���f�����?�_A@.R;��+����w6W_}u�NJ�!�]��T�}�[��|��_m���k�i���w�M�Qh�,vTÝw�ټ���o~��߯�g��O���5���/��W����;��=���s�:<@�n8f�=�h�D>�|����o{{�>�����^�K��.��2uεY��Y���E��UX��,"V,���U=�P�1�����$�����K/msg�F��S?� �Cn������o���V� ���$ᡈ{�QG�md�@Me۩b � B%�$rܴE�'�x��(L���v�C�x��vk'?��կ����}�[xu_ТMA����+�>��V.'�tR+����7+�}��(ax׻޵�8 �<��z��W^i��L���SNپ����_9cX����{R��X�G+'Q;aA��sN��7��9��Û�o�� �����k|%C���H�N=�Զ�*0����k� =������!�6 ��{fa;%�Vp����k�me��!�\$c��V��6��U�ۡ�^g�׿���裏^S����{��>\�?�?�/}���nm�vEL�&/����>yi�CͲmY���)cKl%�m��9^J~k�K�>�otmd �DP �p�q���v[�_���y�mny�1Ǵ>I �W��/�O򠟟�� ��S������9E���K�p~Zjs�>���1����mx+��X�l~4�XUk�I2 �|���a|�>��6����+�}��p�UW���!7���E�/�(MAs���k���A��.j��I���R��/ �?��v���������/���p=M���J1�{��ڤ��L����?�r�j�����X�S��d�/���Ol�=�.�Ot���U� Yy��aȄ���~�?�z]�r�� �9�N�Ӯ�F/��ޅ��} ��w�9��c�%c����!}l�����툱%q%}D��V�σ1'�[���3V�XRk��B�~��ׯ�Y}(����3�I<׺袋�����l�o^��Y���" ����ۃ���m�6��C�oM>��q�6>�����'���v O�ka��rJrU{<s�e}�Q|���#c�5���2R��nG>g >��+x��,"V���9V��f� ͟����c�Xs�G��;#���D��!7��Š�*Z!�[n�en��~��ȱq +�xՓ�W��h� �-�(���EaVU"�飏>�]�B ��;�鬾�u�]�o+ )I"�:�k&��@d�����$���i���J��'M�����-� �!�� (dɇ�W�Օ�����o��� ƆU�%r�����\p��OU���7)�����6�+隰 Cd�1AB��X1�{���lӶσ�ST�j�`�5r�ǃ ɝ��XK�#5>��f���>���Dz�k��"���k��(�8Ƕ���6�3n�����]x��q��k�v�(�cIΓ�(�w��1�+'�|rx��>w�w2?���}�ݷ���W�w� m�+�J��s&�s�h��1lL��E� �RFo�� �Ŀ������{��B|�b��Q��t!���Z�2ፏ�36c�L��-���"cd�e�CT>1�9�E߽�[�T����������%��m����駟��ʹQ��k���M��6�m�C�|>��e�]����$���UȄ\R����;n]N�O9���O�(��[X��[d\��r�(wdi?�W�6s��Z��x ��8�5�Y�.6�=��tH��|m>nv��ј�<�kqM�+}����i^� �*}��1䡚>'�e�7��8�;���~ץo�vQ"�IDAT�)]�>��+���<�̕߾+9}������������m�Eq��Y�bC�l~�������6�~��_��X|�'�W���aƖy���<�`.�^ ͭ�&o�2�ز��� ���_}�Օ��?H���s�T��1�Vaֱ"�r�͵����Y�����.���T��n$��͏��鍊nZ�c}[K6=+jm3I���-����B��`aEi�J�G8O'��~t>%�8t)���hق(h5�U�('�j~O��t��k!#���dߤ�鬒v� �%���g?kG2$jv��N%r洑��$�L�\g�}�m�����+)�AV��&j"�j�g�Ѷ�&� �4Q��%�ecA������u,��|��p�t�q"a���[[9�/?#�(��� ��K ��z�F��O�m�<5m�X �d 4�$V�$@�{��Rk�]c��v��!���f�d�Na�@����� ��%�:��P���Fv�K��딎��\�Wty�(���Ȋ �-����yGX�o���>�O� E2_jlSc�mb/�Ɣ��@r�L�.!V� ?�?K�*�8)�c�L��G�k�4}.�"��/h2���-l�_��P�~���+��r�Io�`s��x&����ݿ�>�4�?�|{>���&��"V�H�,�U�1�6��]���o^�}Y@�s� '������޴o�(�?����7cW�sx(,��_�i{}�ɯ���]v������r�߫�.p>I���"�^��N;��O�q���� �=��^�"��[Ȕ��3�� �j����|�2+_�7�� ��q� cT�[V.]�{(#/[@�=��� ���������7�^{�����7�6�ci���u[�ž���A��X�I�Vc�����|%7�<�� �hϥM��a��&.��ØS���m�Y���{�?��V�k�QM��~���D��p$g�H�����fx�½�zk��̛�?{;�R���g �"B����J[�'��b�|�t�s�d������~6�]�Ƶ�Y��:\�~�x��qP��YQk�I2$�� ������6>���x,T��Q!y�Mv���4��Ro�N`#�ĉ���d��$� Hr��-� Q��6x� ���&h �֩�0�c�k)a,(�NOf���E����WP%�� t�OZ�Ќǫ�˵j��Jd�m�Y���x��TX�I�����>�;m����_�_A��I2]"�_)�ku"9IG�D[��]�X�E�$�dn �Q��N�%O��Q(��b�%)���g�T����!�6 �ؗ���z�$�q�߳�x�d[v/_���;����|� j�W��)g� %"}de'�=�n{��>�!+�M��^gR�k��+�?5����1��eL�6�V��!���x�.�O�!"���\��m��"+&z��D�x�e��W� [$��g�7�K}&n��~|?�����+�\# b� ��L⳷Ub�A��漿�?p�i��(F�����*�ʷ��|��W��p� ��������A��V��s�]y� ^^ʟ�>�������~ل��� ���=c������5�!tm[��d G��@���;(���d䯧<��#���|�o��_צ]VO�����k��v��Y��x�#�Dl�����:K�9VWF��ҷ��m�o���ַs��1�0I>�� AmΪ����1�����rE5�h�x%J��0~�)ےβ�x�EZ,����0>�Opm���P�%�`ͫ���e �"B��»�8�oj�m�>J��6���Ϗ���]�\��Z�+������$շ�ub�Ԕ�D��!7��B��,y���p`�N`�~$�I�M>p�T��y:����d�(�7V�$�@I���R�˯�"H)��hq�* �tj�& �S>�+%�ϱ��:y�#)� ��hi�c�(!�;^��Sj�V[������y��k���T����u�EI�tBM[Ј���z��ia �_OdP�1���d���!�6�}�>���Kv""��IOT�J�ul�/^����s9�o��cŖMv#|dW���L����_?Y 5�Y+슕P֏ʷZ�����s�/��� �8_��D�Oh5id`�� ��˶N;������,����_rC�v�,�e�� 2[��hk�D�M��F2(���| ��U�����E1���X� 9@t}��h�_��K}���=hr�Gy��1�?E��h�\V~�4v�E����^�+9��K�tmlW?#��J�I� J2?����s>�揷�F�ѮBU��EL��jG��/_�K躊W�/c(ǩ}�6��FQ��j� &�gI8�ڟd�L��R��<J�e?�Ά�6g-����'����������W�H_K6�v�ȋ��b�8J�m������\���Q:?��<���.L�q�c�J�o��L�%D���|]��E60+jm3I�D�F"���}�gF��!7��܋�<�ı��N�w�N`�~j%�}�DX��`�➂�VDx�_r�P 0@�~��ۧ�<Y����� �������O �5���Y9z�%g>��'�UPE>� y!7����C��6X-�?"J���Q-��8���\�ߘ��vDr����wc���p�RLz`�,�+k��*�:-��)t� ���d�L�C&٬{��d��Sk;�^�ڡ�ٱ��˷�o:6�c�W:.�s�D�l� �&���؉ܤ>�/�f����>����,��,���[?ZғHw��sV��Y��'�.���u��Fȿ�"�3�}~BQ�"���D�f|��_Ƕ�3��Cx���>}*��$7��8�^�oW�V4�\�����a#yi$��m*P�R\���F>:��Y!3dgQ[U���婕���o�㩑u����i"U�^I.��r`r�����ҵ}�"��O��t��K����#��ј�9���kc+������B5��vp ^�"|;���d ���䡶�&y�(F9opr���{��d���p?�g*��ڗ~�l���0�y���p=$�9k�?���&�����И���W�H_K6 � !s �O������ƈ|Sc�<�6�`�X���p ��˳�X�)��'���T@���g�]և���Zʏ����V>��YSk�I2$%{┷٨�<�&;�kQgKg�w�`�N�o?U�����c�O�(�XU��οK)8�T��0�"�Yg����ܹ�-V�9h�? �@ə���h_�)�/5�7O6irSA_����չ����=�R�+1�c J���Q-��J�Q;"9q~IG���V}QƟ$J��h��_Ф}�Ȧ"h �}� &�K4&ce��2�Y?�Z�&����qkl��! -c�~��7m{�񒞣gV'�����}^�K�ED�܏���s���� ��X���s$�d���fi����ڒ�D���9��s&��KV$c˼E� j t]���&�v%���m0��8��w�xH�1�UkL�i�nu���V���Kn�G�Koy�_�V4�\�������m$/�dP�1�Ǝ�k�����q������FV� �Y�V�y��/�Y��|<5�.](F�{Ȣ4�=�-]۷/� ���,J�o٢r4f}��&(�E9��6v�����������N�Mi����l_��W�7�xФ�"9R��p�=�% �$�,]�>x=��ob��!7� ~��<��4盆ڜ��~���|G�F#y���>��W%}-�0�봉Č�Υ�ܗq`���k��߄���b-H�~�ۯԝ�^�E� Oi�=���'��(�G��V����YSk�I2$%{l���B��`�Ei�ʅ����y I�~�4�@�o�Y�C�B����N𰫗��%���&HL��$U�;����=����#�\�: �A�������}/���3�z\7z݈�j�Yr�J���&����(:�}��1��_}G��!4�E��jD��T���R��M.p68�#�̕�����V��H_�o�{-���fK6R��v��'��ƣ}Vg��xJ}�:է�]��W�G���}#X���s$�d���fi����Zt �B�,��|5zc�9��c�W`����)�u�Cl��� ��L�x&{lVw��;���ۇ����K��\���Kn�"�&�v�>c���h����6��F2(�X2��������~���%;Z����Z�����^G,jE�t�T^� > ?��[Jra����k��K�&�w��H/��YP:N�eC���>߁��� mr=r>ƆB1�)Q;��]�b�ܣ1� C��W�#}�k�Mt�g=���m �^� �:���mg(j�"���Ͼ?��� �|@$��H�g�6��UD��]6 �W���x���%��6qM�f������~⛘�c�؁�+����K��,c����_�>w n�ې��-BEv=H,�/��}�~A�%K��GP�K���z� ̊Z�L�!� �(�ۣB��`�<��~��6����i�w(CR�O^#����+Px��@�y$^�I�?VN��_���p�<����a.$$bz��B�լz�"G�Х����;����ma��ɫ�͓�I;�H�1����}��1Q��W��/������5�o�W�����I:��G+]����$�-��"�D����wy��$�.�@��bO�b�Q��{�ER�C��l����d;����Ij)4&�$���#�'q�^��|����^�P2k�O ��>}.�#z�Ji[X�����������>G�J�O�m��J���E��;���|��xN��W{?�_���Yz�k[���a�&��'}�o���B�����.Q�O%�i����kbI���(�#^�O}�~eo@��G�a����?l4/�dPұ�&m$� u�| �7cguE��u�Hi��ʿ�g��:b������_��ױ����*��Ck��\"c����;Ē�E�� ηMz1�D��/��y=��ie�_��K�����zE����f�?��8J���|��s��i m"'����t�gm�ܛk���¥t��+E;d��cCQ�d7����}�|��j�UD��]6 ȟq`L?���^{��n^ *���3>���l~�=��<]�8�X�1v��seo��uj�С�ȇ��KW�W�S-�K��Q.`u�d���6�dh�ؠ� �va��㨐<�&;�(��y��C�<�@M?N h?Ya�S?��8E��$ >�����GqD�x��"�w�8p4�8m���WNQ*~oѪ�� ����B*�PJ2���@���7I�oO��"�����P@���uP�.��M�D)�A4^%X�~��D������/�� v�z"j���L��e����6�U:˘��=t������t��4Za]�S ��J��{�r����C~}�hj}e���~�l�j�y����� �f���O�?DҨ?��Ob� {�O���>��2�$y�)Ǥ�~����}����u�+P����Q}���w9��*���g��{^2jl�4V�o'E�1�:B�����W�g]���o��O� :���|��ߛ�[ZܟI�����4چ���p�cE�u��Rܟv�Vba���K��g+3��9{�h�l��-� m������k���U���D�(�St� "��tɶ-:�/��/�����s=d�X2�|W�W�m1U�GGX-�q�$�i����g�~+�]�ܔxH;�!�lǾ�ȵ��(���Jy ����"�е�'�D[%3쌂'H/8��D��om�{[{�.��A�o՜/},��m�\�늒`E5���$��N��?��θ���8�h>�-��Z���Fߠ�>�;�ؕ뀊�^F� f�7�����6���8}��}�����?��"js֒�������ma�!Q���s]��叼~2.>^�3�5�Ồ�vٰ`a�"�[�S�Ͽ���lA��oGsn�s�1� �8;&�K�k��t���.��8[�z��c�_�ys�~K>D������GB1=B7e�����m����Mb�`mtjm3I���_MP�0o��v���dY��s�M�M�q�6X��K`����������V�6E�G}�=���3ϴ�����6�>���O�6q�(x� g]XQ~�� 9ΝI4��l{�Ɨ� '/C �@&\C���'�6��h��j�~�w���JicAA�'>�뉨Ȃ�!��*��$]�m�8�m۶v  ���'�`KrG���S�S V�06�8��X�J��'� Ԋ��{-�>���f���D��x=�$o� �={�G�����V���'�|r�ݝ}��+{_ON��I6�u�c��3�/�s��>r�ݸ6>��Y�>}�|��'����M��$?�̇�,����I�ă$b >K+��|uM<'nr��!�W�p��3�Cw�=�����������3�H���d�u���h���]��Vf��c�>k��y�J?諕m���jw��"�O\�"7�� "��Xh[��u�||��Y��m�[�St��+��]������ʇ�� ���#�\%g�q�끷�����R�k�/�aK��}פ}7�t���#_�k�ҋI� ��~oC֞�_�Ǘ�L:�c���ȶ�y���J~��a�������]w�:���O�t�����iKr�O�Gz3�Vߠ�>kr��yIr=<�_~y[��,��| ��(����SO=uM�Q���솟}ȣ��̓}2��7����I� �����@���lXH?/ h��H��'f����?��^c��9�����r�r���;��g�.α���Jnއh?r�}GsY��8����B������=���;���3� � �F���6�d�+m��y��,*$�������ɘ�ٕD%ɬa��NX�N� l_��b*M,�q�Hۜe<g��ۮ��D,Z͕,Lty��XF�iP�aYb� �x�v��2��g(�P\�Ȗ��>�͢s�Y����e�c#cEL�- ���$�!*$���(�@�(�, �9���j��UvC�Sq�i����2�ی���+7;��䛔v��-�P�з�,�63�'Ӡ��NZ�ׇ,J/����Y��YtΚ�h2Vl>m�IRCTHr��E�{�(�2iM� O���E7���6+x��?��뒼B�kS�^�<۱Q������z뭭 ��]�����/%��"m3�y�^��7?y8l?+�Q�аx�,7���y��5����X�yY�m&I Q!y�Mv�E��Ik2o�<���A|�mޯ#�m3}�4�^�2�U|�f�����~!6�k�<<I��E�f���b�ߡ���m�i�B��I����>�͢s��G#c��eѶ�$5D��!7�A��$Iz�>$I�I�f�$I���q1I�I�f� D��!7�A��$Iz�>$I�I�f�$I���q1I�I�f� D��!7�����p��$IjI�$�$m3I�$IVɸ�$�$m3Y�B������(�$IRC��$'i�I�$I�J��$'i��2���dwfQ:I����!I2N�6�$I�d���I2N�6�e *$���(�$I҃�!I2N�6�$I�d���I2N�6�e *$��(Joˢt�$I�C�d��m&I�$�*�d��m&�@THr��y�+J���+���7�*}�-�܆�҇��8����r�-��r[�2.��8����ƼE��!7ݧ-J�c��[eK��-��6���-�qni���[n�嶺e\�-�qni���y� �Cn�Ϻ��V�O�$���!I2N�6�$I�d���I2N�6����ܶlQ��*��$I�'}H�����$I�$Y%�b�����d� �Cn�ۖ+Jo�~&I2҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;��(�$IRK��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���d����,J'I�Ԑ>$I�I�f�$I���q1I�I�f� D��!7�A��$Iz�>$I�I�f�$I���q1I�I�f� D��!7�A�g̷�����xG�_�be�x����ޜ}��� '�����]ٻ�X�1I��"|��>�|��h��=�X�w~�ӟn���G�H�m��l�8����n���o6�vX��?�q�����9��s����m����f��wo>��4�������+G͎/}�K�>��楗^Z�3{���{����0f�c� G�����C�v2>+M�X�ӟ����G>����+{fK�m&�"� �Cn��;�Z@Q��nv�a�6��m��p�~��0�y�[�Ҷ{�=�h Fv-����8/������E]�Nz</��Bs�Ygm����,[m?��c�O}�SS_c�'r�>AǏII��1����w��]�������?_��>���� |��X��4��׿�m۶5��o��7��yӛ��r�!�O~�v�mQ�w�y���?�����H.��˜krm���8�K��O�Ss�y�5��K{<����M�$K����O�M�A�Qߵ��u����۱����W�l]���Y��%�Rc��e|�������<��q����׾�&����nK]�q$NЇ~���������C����u_r��~���]w��\s�5ͻ����X�g˝w�ټ���o~���^�S�4֢49����v���ϣ�>��;V�x���{6��~������oosg摖W_}�9�����~���?�񏪹�r�i�#ѹ������/n������:�|�l���0�_���js֡u{�����Vf��m~�'V=��C�=2����$�����K/msg�/��O�B��`!Ei:LRq���7_���lO>���Q����]��m���N@p�W\qEs��77Gyd[H;�c��j#��N9�vR�F=��S����^��'�h'�o����ͷ�rK{,������'e�b#I`}���H�$�GuTk�L8'Fm�WR��w����o~�r�*\�®m�����ln��檫�j>�я����m��LɵJ�# S��8+s��\�{p?�~��^�෿�m���{�:F[���2W_@-pH�v�����ѷև ﷾����� ^|�ŕ#�� a����/J���6���t�ǫZ]�%_���ۂ�-�ʇb�j����w�m�����vkOP��sΚ�������O�%5c̃ZVVهгl[D�gc��*���gQ�.��i��G�XH1��� /l���7o��y����$��2Ef�͂ߓ[#���\��[��ͱ#6"��\��s��<N�ȧi3Ǟq��L��yks�>���1��H_� oe+�͏��jm3If5W֩�H�� l&*$��ڢ���sQ����iޯXBm?K� �= p�hG�c0���$eRb]�OΙ )Q����|�ck�Ϭʵ�XM�c'�ca#I`}���R�Hdxp���o��u�+��;��N����_n��o�5&�$�W^ye�jX� ��Op������5=�$Iץ-�*V�v�i�����n�gW�)�F��1 :�.Z���h������!^ϒnj'DC��,�㋒a���>�SҵZ]��!�B���'��%��I<�⍙҃�10+;#/E����G�nVm+��Bü��(����ch��+�R�[Ӏ�)�ӂϡx˜�T$�����eVs��;ƃ<�P�mDNѹ�{�G ʹ�>�����0'�xb��!-��}t;�9c� ��z��,"V���9V��f� �j�GqD��+���]�"*$��R�&�`e +L�ͤ~*A$0k�I���'�2!�}S�r�}�5'�tR[`�9�� �]ɑ� EF��X�6R��;��Y����t�M�JV%Ñ�.%Y>�q $M�I�+��+k]����nh�DWb\ :���ƀWlm���T���CAQ�Z������Q`�!�}Mm���K��E�QL�_�?/ [>��O�����]z-���W*eGҭ��}����Z��.��Zyx�|O>������� b��9����]d5$?�DC&L�� ׳�Ò��q�Ϭ�>j~H�U�د�ڒ���������W�P�_?ϧ J2,�&�=5�iLJ��72X)�m�g��V'�ޒ*��a���1|ۣ�>�r���:Ŀ��n��*et���{�!�Ud��ɂ.Z�[�d6��q(@��Z�2�!-�3~��dK�����Y{Y(7�o� �!KC,�S%��|�@�����6L�B���g�U���p�ݬ.��ç ��?��6j�{�||�iWM>�.^v�e�lL��]u�L~��o?��w�q�0�~lŶ�j�1�w�o�w~�����)+o-Ȓ~**]�<˶��踮i�ͺ�k��kRl�hLmާKa�ʐ7����7�!v��[�C����}����:,�/�7z�� �n���t� p- �ZѕKL":7���]�O�zD[�/��kLKm�*���X���(�>�_l���l���M�W���/�o��?�H_��ˆ�9�+��s���{r����alY��X��W�����{��^6f�)VD S����w��ݶ-��3�P�8�s�SA�k#��@�m~$��v^���m� ��<���$� b�_�����B��`!Ei�" +Q����!��O��`e&��%�\���S}����ҶX���ۉ?S���R�- }>��3���䈧�\C�n9�]wm~��_�?{��*�o��u�<!���g��ɽ�$;�PP�=Q�6�O�IQv ���S�O��MP2G�KDmg�/��o��S�MJ^�d���Q:W �M��=ǡȎ����f�$$[��8ƙB2:G��?�O�� I�*P�=��)P�!�*1M�M��,َ}` :/���9��QH���J��/+@�3�������O�=X���٧���$c�' 3萎Çi�#{?���{0��=�/c�����[�d���&�/ ��1b��>������g�Β��8+���}�Q�����c�$�d��ئ�߈���sb#6�䬔�cK�jm��5�����܋�zʄ ݢ������pB�4��Ei~�n�u�/T��.^��=l��{Mz����&���sh?~���oϗ�#_!�[Y #~����X>�1�v����~�D���ƈ� ���r_�0&���h�KL��>��]�Z��~3v5���Y����q5�W��� ~�}�;��>��� .�O�^�Ӷ���v�i]�M!��<�����A�m�K��dJ[��d�?�Z��8�#�澥��5�9��b�e�t��@����� �B?l�+_�ʚ�Z������Ȉ!�������t��I)��!:��ӢqVn�'� �H߬�(�9�t�1灐�mk��������(nPDf��v,j�QM��~^/D��� #s|�-v�F�n�c�o�s/��ܟ��ګ��~̙i ���g �"B����J[�'��;�/�Nq.׀I���r ��h?�ڎ��\��|����rw� ��<���$l_�]���w�{r<�_�-*$���^��s �deI� �E��W� Mm?����I� J�����A�`��F�#�d?DZ)I�A���=X�A�$ p%I%�5�״D���I@��`H@Q���BR�q���5 ��P�ڎn�>�6���)jc����|W3��ဒ0'���u��|���A�����k�����XYM� ���%�%�s�i��hj}}�����8���k�cjY/'��?^v`����~� 4J཯PqW?"{���v��Bm2�L�^�Lb�<�C���1��`Roǐ ���9�A�'%�$���65>��]������tU��mGm�|��,��+.u=l\Ͽ�,O!���ɦ��|A�A yI)��J}f�+���c_�Cz�^�e墕v��8n}��� l���Zcg>V���<�� ��(�5(xj"^돼σ�!�$�%� 5��o��&���~ۜ�V��s�]yw����}�}�ȯ�/���y�ac~?�����z����-�m���Z��&�H�hRl��o�9����t�~�#~�rM�O,�|�� �W��~vP��s�3�<������j�q�vJ�U��E0��TKt���G��� ��� �g�y���W��uk����m[���cS��k��G:C��?�&^���F6��0�-��<��G�0�$�����~�k3�և�������2�X�9ح}��qP��N�.��%�@�_��"ʏ���]�\��*w�ڸ?���$C�،����AM�h[� �Cn���/b�4��NpT$�8[�����9M;��x�VJRx�j��ǹ~#�?%]K� @��%��G�-:��$C�V۬\- �0�$���O,��Ǥ�}�۪6E���5�0EcB�c`�$��M&��~�f�a��v�@�N�D��R�׸�q�D�?��%�ɴԏ�ևЧ��l]��G����Edà�m! �_ו���0%�������S�B�|�KHV��j�5j;��=����|�M`��q%�$���6Kヿf%��Uow"�Ւ�+i2���Ƨe��$��&b~B�I#l(6w�����R�%7�9#�_rC�v�,�e������ G�A{hW�q���p^�h�#"�t�C�� �"�R�8��|8O����1��-�X���N��/�9�+O)�P���2��S���� �*J��������}����(]�����H/����q>F��f��V��A�0|I�hC�ou��/��3:m}�k�6�HN �Y�����N>�@?X鿛ɩ���H6�����j'�ض� `_�G�Xi��P��%�F��_����������W�H_K6�v�ȋn�b~D:H���0�B���<��=8�s���˳�X������ao�����V򃲳I����^����z� ̊Z�L�!����ȧ�g����Ѩ�<�&;XHQ:B �wHCS�O9<Pҩ��Z���ݏd��[���hA� X|�KN���q��_�tM|�"H*H0 � �P���E���MV���c�9��XuQ �J�V��{�L���9��aO8}%^6�=�f�7�Ji�B[�����L��ES�C�z̿^6A��u�]�&�<��c ��r��%�/���n�W�4i��O�}���ɢ�^�5�U(V�j{�/@[�&��q�v��E�KfK�m��G�����S��%]η3V��j{�[�^z��P#T�����g��8EQ���}�r��/�!VaK�k&�Z)-�X}�O�>������k���J׊Ƒ���%�My�8���=��x�7V�)ψ�8"�AԶ (�1�Oه�5��q�?�J�Ȣ�*��婕���o�㩑u����i"U�^I.��r ���!v������~���_r/��g �ј�9���dX�%��1+��Os� �>�}<D�:�|�����G�o�R"9�����W�� !��_M�b?-D�{����P���t����E��m@ �h̥��G}�'�ג �փ!t�y&��v~�=�����{��y�G5?b�ʜO�k��^�E� Oi�=%��Ndݏ}���j���R~��Vη��?ϚZ�L�!)�P��6���d߿���1�q&�VS Am?#G8�7�#��~;���`�#%Ht��Uz�Yr�^)#�]j?������=آ~z� ,b��*N�o{�����&��9��CP�&A��-��P� �$�$ԥ�Ӕ�(��f�� �)��}���oJ��Ę>S(��A��FB���7�m�M��zA����/�ǡ#�J����Z٬Ò|Kz_:^�uݮ��Nk�S{_躷�����_ȱ$�=�})@��C����-C�mpõq,[���̖�,���[]-�Z��%]��E&��mV$#���&�%�gb�VG�&�z �C ���9���ݸ��~z�t�����&V�Z}�/�>������wV��kkc�U�Z�8r=�C��~S�`5"�f?���q��c� �GD2(�Gc��jVS�#vk��l�����Em�lEi��,J��~������~���_r/�ll�h�����+Z R�aI��oǬt���:���s(V�"�V����>���K�{�W�����-J�]Ct.��"hQ�;����Xe?��P��%�g?f�x�lyt��-|N�J�Z�a@�i��:��r_t�y�]y�b0�b�h;c+]�~�ۯԝ�^�E� Oi�=%�@���!��Q~]m�:��5���$CR�7���"Ĩ�<�&;�{Q��P�{�t hHj�Yr�LK �I� H%��~�K�#�,���8K�$�&�sm��x^��.����q��R?-J0x��J-�T���2�&�v�������&�;����������U�<�t����j�oQ�Kɓ��$#Jl}���������?�t�'Ġ����A�-���׭��}����g�� ���Ò|����گ�j���ߧ�t�}j� ��`�����b�%2j{t����RIWEI6�쩱���h��Ւ�E�Z�u���r,� ��鮇�\�ɬ-��V��L�x�6�/��F�K|��t@}W�(��$7���)L�}�-z��?��Ƒv�����q_�=N>��,m���H%�@�7=�,j����=������뤫��/�Y���X�.�:�0�)�� >@�� (�}BI.��S�eK�VaJ��������_6T�!��>�o����$C����V'������ �B������j����>�Y�������c�)t���{��n�y�HN��9|Q4:��G��(ɫ�M}��YK��Ͼ_Q�K>�$�j�UD��]6 �W���-��̛�%��k�6��������"s����:��^�E� ��v�s�� �x�"d�z�(G�,�+��,iO�AI/����E60+jm3I���&ȣ�#�ͫ��:,$���^�V�a_�V�i��,��g���y���� ��>�sJ��60��c'������ ����� ��g�@B`�0� O"��P�����@���)�[�`�EI;~Ȅq��R?=\�����k� )��*<���d �)~���t��I��_~��>vR�k���ȸ�I��i�G �'Q�C�-5����o?<�Y+/�O��c���w��v|�:�n�c�]��/%}��hj}�z����KCG��M�����0���~]W:�}��cH����r�+tD���/�&��> k��}�v"�ab`e��@u�G��C��TlM~�>�'��� �=5�Y���ZҵHW��Q�e�k<�#������5z�_E�z\7zhG2Ʉ�?D�dP��o�JV���%�.�M�%7V_��I���G~�|���ج-�*7��H;h��”�ڌ��#����L�y�^��ɠ�c�F�q��vZ7���D����t�Hi��ʿ�g��:b!�����/����RNW�C��>�D6�~+?�Mn,9Ytm���|ۤ��A�?���!�Q�!��>�#�R�Z���A�~�������MA1�y�#�Zȭy�]��|;��3���HNƓ�h�?7*�&�TD�Q�~#��%��g߯h�K>�L�G��*"��.t�2�C?��t����+,��H�y��`�x���uq�{y�ˢbE�Zه:����u��s�-p�bO��lT���ܫ��饟�"��՝� ̊Z�L���ob����z��S�S�B����?�(�����8%��J��#��I��zgAm?�8z衭���V�2�8P^ �1y�m���LKI �m`(9^�i��Xg�� Pg�}vI�z$�$�~�5(B�^�H��U� �g�9��Wa b>�q-��S\ƕ�E&QHA�N�� �}��x�}�/W��j(I~p�)%�Cc�옔ڄ!r�}��U� 6~�5�jv���|J+����IF�� 7��n\��1�=�{�E��U���g�s�ᇷ�<���$����oۉ)�0���C�E��`�L��U ���ES�C��ճt����oV�61�cXJ�"����ou�{��<�b���޾�'��D���D�au�>�U�J�n��#Y�ث�({���7���Q���q��~�W��q��R�d���fi|���j)�tU:�n�8km����k�9z����� /l?�X���ôI���D �-s�q��ڨ�QQ�~�T�g��]:\�o﯄�˯���%�(�F��o��s�=���!���PĤvi��]�qbvJ����"h���@អm� �K�mѹ���|q�V>��ȝ�!�|L�GGX-�q�b�����g�~+�]��s*R(��vl>˵����9϶7;@.֟ �[�ueum�-�V� ;#��c��A�?��ֆ���g邽��V����R�Z���A�~�ȁ�^�C�� ډ ���'�1���o܇{���K #�W1_:��%�Dha����J��uy�}���i� ovp�5�\������ ��%��g�/4XPAA�����'|��sȅ�r�.���q�� ��nk!GI_�lX�P�vǭ�1���_�y�ց}H�wѪ`�s�1Ɗg�}�����h>F{�U�U���ض�m������;�Q~a���e��Ӣ��U���#������Bϐ�����.jm3I����"K���se�O��B��`�Ei��q�{�Gk�a��}::+j��3�0F� g�_c�!v�am��?Vf�\B)Ia� %� ȅ��6���Gxz��%�����i��X�E � r�>�|��G��k�.����I�l���"����l����ɵ�Mm��$���9x��>�E�p.�U�礓NھrYcRj��%�b�D�Ys]��o���K�`����m۶��6+D8�i�� �g�8cjst�@fL�CȈW!�}�.H����Q�]tѢ���n^}��hj}�l�k�!�Q���Q��ǰ���l�t��{� ��˴� ����^�Ch'c�=�t�M���O��r=MN�F�$O��:U�W�����xc'vu����$psM��ح�4�쩱���h��U�'�"]�Ny�M�A #�Z����3�C_� �W}��W���Q��X[Ʒ�c���:>��]���}{%�_>��Q>�c��Ch���O^3�����.�G��1����6r�m+ע��5D$�HǢs~���U�P#�oŞI��[V_���}.;I�Q�A��|�� �W�HE=��z�_��h�@r���/�aK��GpM�G��}��;�J/&��H@�� ���߂I�sl�9 Q�ad{�~���8,�F6��΁|��$h�iT���Ix�A1��kӆhӘ0��?�k`K��Y�M |�Ϳ���%�2��vꩧ��@~�E��0{���ڜ�d7���E��` ,��o��蔟`� H.5�hR��g�;�D�:Ɇ�Ɵ<���A���h��uN+����>�c�@W�.y ��*�J�9�;�X3������%7�i�~�Vʏ�b G(ԫ� �C����4C�_���$�_i�|���DTHr�,�(�H6s?q���4>�?��E)LC�dl+����V���d�E)i߬���[�W&�o�&�d��9d<�0e�m?���X��+Y���К�*� ��m%(r��-Z�ЇY��YA�M�Mq�"[�9Xt�:+T�סlxld����eaѶ�$5D��!7�A[��;�қ V���v]c.J��%��c�B�����iW�D��73c��V�[ ����]���_� +'���e,B%�G�����Y�^<�����5��0d��|,�6�����<�&;Ȣ�f�Ei�l����g�$� }��W�c3�:��}�ҧoF�P&�d���E��|�W����6�)�����œ�  ��Y�m����E�f�����dY��Œ�(MA�B߶��`A�,��!��]�ҷw�q�H��"T����T��m= YhX<�����5����X�yY�m&I Q!y�Mvp{��$I�I�$�$m3I�$IVɸ�$�$m3Y�B�� ��I�$=H�$�$m3I�$IVɸ�$�$m3Y�B�쀢���(�$IRG��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���d�o{����_z������l���[n�o�Cr�m�[�fn��[n��ns�m�[�fncޢB�(�U�4��r�m#[���r疶�[n��[n�[���r疶�ۘ���<���+Jo0�$I�iI�$�$m3I�$IVɸ�$�$m3;Q!y�m��1��R|O�dx҇$�8I�L�$I�U2.&�8I�L����<� ��E��?t�$IRC��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���dY�N�$�A��$'i�I�$I�J��$'i��2���d�eQ:I����!I2N�6�$I�d���I2N�6�e *$���(�$I҃�!I2N�6�$I�d���I2N�6�e *$���(�$I҃�!I2N�6�$I�d���I2N�6�e *$���(�$I҃�!I2N�6�$I�d���I2N�6�e *$���(�l��k��O����X���7���7��;������w��|ȳ�>�|��h��=I����fƹ́�EƧ���/͹�ۼ�mok���74��{��|���������\9jv|�K_j>��4/���ʞٳU���{�mǘ��1c��d-C�z�R����7?����O���O�|�#i����=���6�d�D��!7�A[�����L ~�4G}t���+��w?'���������������IT9�`R�4�{�;��|���.N����?7W]uUs�I'�m�<��:���_���o[9����?��~�����&y1!~�;�����X9�u^}�����n��:��o���a���~xeO7\�{D�Ц��O��Em=�P󖷼e�.HW?��6��ډ��{�ٜ~����,�~u�����}{=|��������և������wC�84�����6]~��+{�#����|�l�$Y45��?[T�������{���_A��7��=uD��ꫯ�����S_^x�6���!�=�أ��;���_+G�辜�կ~��뮻�k���y���=7ˢ�l���;�����m�2t�n�Eir�/|� ��������k|�G���4���{�����<��w'�xb{�id=in����I��3Ϭ�|�=^�<��6gZ���Wamx+�U��6?����b�۶m[�3[jm3I��ܖ�\�OK�$�D��!7��B��� /��y���x��� 7��<��#kȬ�g?kP�Blբ�U���.���ԝu�Y͛����K.�^������7�L4q�ڪI"�s�G�s���/O�g��^{��^�nL�)�R��KA�BPd������K�HX��%^y�6a�O~;��[��s�9m�Ut�~����Cm�#<$���NJ�*�Sd��,�7 !���__��:��]�z׺���|�=��X>j}��ַ���W�'1>��S[�d%]$�.4)����N:�>��O�ѥk���ݏm�}��+G׳�yQ�*/5��GoJ�6��;>�?����x�T >_��n��r�k�KŒ12��S����?�|�Cj����28�3��t�?��]Y���~���l[ �(4̻���1el�;�6���g��o4O���Ҿ|���f%��g���_��}�E�o}:t�QG�s�je];7������)���=��+Z�PȊr �D�(\�y>��ͳ�6g��ۑ�)�m�x}o�[�EĊE`�1�e�Z�L�!��𖚕�d�<��o��ּmHM(*$��R��hG��ͼ�<�9 �#I!��,�I,�q3����_�ʞד�3�<��`�`+���c"�����zm¿�I(I,��{����K��¸���,�dO� ��k���M�?�я6/�����~�d+o �p~���I�@��̄@����j�]v�e�������Õ=�C�@����{�{���'�>�q��M�9�����f�I���I�J9��H�,�����֡�6��M�ަ����Ǔ8Z�_!��}�Do��I<׺袋���11���(��b>9�����)<��|�m�a��y�qQ�M"��ж�[�e�y���Q^�k�3�~�|9����5����]����C�ZYK�����t�$W�z;��[B�]�:������Y��v�sJr�'^_���Vf�b���h zY��6�dH�:���?n�q,����<�&;���9�)ZP�`³� ]�O%g�ə��v�u��W����Y���W�R��HG��r�7�EW S>�铨2e�. md)�/�����阛n��]��{�q���iI?��ſ��d�cY��v�!��I�J ����HB��/��' �'Ǩ�; 2?�bٷG2f�1m��f�>�h{���ZC�PX���� T��j�#�<�]�l ֑����_V�w�<��7�M���-�[����Q� �e&v���Y�Nqێ+}���ެ�y����|���o��B�"���^�-{k߼2�K�Bo�X��~m���[ؠ���{��4��~�'Z�I��q���Fy�m�}�m��� M��m [�,�c��j�$Y$��۴��}������Ӓ��v�mE;�95�$����>��U��}���0�*2���K���v���c���pd��O��Y��LA���v#[��\��12F�^�B��q�p��1�1rI�||�@�����o�����8�>be��%?fu��'��b�d���#�F�k���M��6qYc�&&��F����_cW] &D:��w�q�rڏ����~�^�z�k�$ 28�����aSV.66y��}�Z�6�P��Z��x� ��8�wۘ'�]ۤC��k�q���hL�"� �g��� ���/2� K�,�����g�}�}�3�ʚ������D?�]�EW������3;�����B�yS��J�����!���̺�ƿ��Ȏ ��W�1�f?>��+p�0c�+��kq��7j��5��ֆ�e�Oc�[�9���{�����1Ŋdʱ6W���ϜR��Xα�.ߵ�\B��6?�^пI� ��΃Z�L�!�6�?��u����.���D��!7��܋�8c�:N�:��|�+�� fMM?�O$���N;�Ԯl��1�$�6�p��)EJ�j'��P�" D����פ ����^;��-8ș�2�f^��1s��!��>~�1{�G���ף� >��1l��}R�s���W�2+�m��q)8�n�"��Uʹ�D@ �dLIX$���Nc��l���_t�_~&��w6yQ��i,�Ǥ���k���c���O�� 1b"@B����|��"���� ��g ����2I�C�PJ��$Rn�#ƺ���Wz=�x�����W�J�A������`��Y:���L�9׿��q뭷��˿��u�&Z·�c��^�ׂ���^���k�p� ��pOv1I���P&,l�_:5I���6�|�>��n⣈s�,�S�7�%;��L�'��7��[���ɬ/J��of2Y������k�Ll:�[&�����O�"�W`�L��,l�R�!�@�I)c`㉏O�_��$�������r_|> _�}�Mұ(� ��fts��� ����f����]�1����O�����9j�>w�U�c����bpb� �E{��o/q����+�8 ����֞�A�m�K��dJ[ɽ�o���@�q>�f嫘*�7�U��wO�&��a���_�|�t�+z3�k�G�Kߢ܂�s ��fe"je��J�']�_���z]�EW�����Y��e>��pol���,��Y%o�\���m�~�ܭKn���&^q?l��x"}�lX9��@�;>_~�|��*�+���Po��=i#�x�{y�+"_鿏���{r>ة��K�8�k�$ɿ]���~��MmG�_���r>��z���6d�;jm3I�b��5���ds/J�0x�� 9NM�f�4�ġ��Lh%��#H" 8_&�|���� P*����&1duR���A��@��G���'�(9RP��I�]���&)ГW�| �zr�> ��Q�Q�-9w�i���"����xJ���myꩧ� ��1ɘ�)0�#��W���#��ӂ�|�<?����P���A�줟D�����f+/ I��c[�k!;����;&�/_?V:N� ���r&a�>(�#a�Ȗ��D�j�?&j}��s��Z (�Cd`߼�=�$8� ���L�X)����m2�����( g<���2����yd����t��,��G�mJo�u��l��P��Ȏj� ��϶�t�/+���W\Ͽ����8$*�(2ٴ�$�3q���P�"~!�Iߔ.�Y����1S�Q���+�Ȃb�b#n>����v��9蠃�ؿ�'������?�d�W�Y�3�*�0�x���7y"����|�F>������l^�y'���659G���ؕG1�� ]�zj�a���EN�~ل��� ���=c�W3���l��k�B�&[8��:�߁8i�O2���C\[��V���O�~]�vE������k��� �>2$_�'xyB��=�Cd{�Q/�u=�����Pdz�\�����>aþ���6g���"��c��+�䆼j��4�Jp�H_#ּ\�%�e��s6��� �]���ڌ���Z|�b����!VDp~�>p�8�oj�m�!$>J��6�Q~$��T���΃Z�L�YC��=�k����<�&;�{Q��{���8��!I�~�6^'[�`?�6MlTX#���MEI�_���^���A@J� ֡ ��5����W�Q���藮�I�/.�c�G+KΝ~�Z%7���yQ[�`��}���6^ݴr*��R0���XAo5%�V�J@$kd$���#�C�a?�A�g����J^�`� �~�I�){�'ɲ�%]�Ɗ>�g�_�B��M�l$>c̹&2�>��9�G< �[�s7�h &ل%:6�ɚk�l�����$�� XѽK��d�+�Gn��Rc�%��?⏭���&���x"?����I0��1_1�?i�H��bsj���i��6���R�%7�sh��\��G?�9N+��pSD�X�OJǩ}���_��� �AI�<�Nr�9�A\�ĹF>���y��X(�P�Q��&稕�ϑ]y��"#�'�$����LQ��sR�����/z��>�W�+*.�ҵ�ml\����?('��6(��8F~���@ۘ������;m��PU�"����Ƕ�B.�[ l��S+k�#�S�}��'�J�+�r$W �{="����=��#��YQ����M���I�גܐ�?�?��<���lX�T��q�/��ŏ(��n[8F.�6���A�{p,�HG���gѱ�����#��b vaWz���lnR.!�����`k��"����$��C��Xl��3Ϭ�f���<�&;XHQ:r�������O�a�KB���t��1A �J��X [�V���վ#�j�^r�9Z)��$璓���G��׈�Q���$Ť�p^�V�J�@��y]��C��9z��%c�Y�4(m_4#�r}�^%/��(�~%9� �#��O�K(�O��sy�N£�P%]��HªJ؄���:�d�˔��HN�� 숄+�@-�Z����.�'����@o��cP� x��̃^����c#��dg [����j�g�����$������K:_#�����"�|��fIo��ƃ�mDv$��'��a���w�/���u��F`c�J��L~�>(*o��D^B�}.�,>�xI\"~���ޖJ}.�M�%7γ��Ǖ��c�O�}z�b�׎�����J���;��CW|�d�-B��V�)G������AV� �Y�V���<��/�Y��|<���'�t}��r,]�$�{9P��肥tm߾H/��?(���{��>�`�Y��~����6v��HN�"��t�+��}٢Oԕ�ܥ �,���z�McP�~W��'��3s�h,fAm�Z�7?{���Z����t\��O��D�Z�a`n�C�_�cO��������g�DLPQ�9 mT��Zs�a�{y+<���t��SY�c��ds�ou��u���|�ϳ��6�dVP�$��6� sg��D��!7��h��rHL�fI�~���_�$�$� ��Όœ��[�N��+$��-9h�-�ZڀRٍvh�9Y��{�:�R����u�ײ���'��|A���Rt���L,�h+A�1m�Ԉh�M1�vS��E`�K����۾�6ҎH��1�JS ����E�y�b��U҅����FBi%��ڬ�h�Č zm�Zc�և V&�Kl�'�$���&+��/c̷��D��D�ýx������=_ߕ��F6Ycϲ����{�U��_�b{MV-�;9_������V����E�����Ho@�m<(�FdG���x�Ē���d&�<@��������&�z փM�g�Hs����O?���1�&�(�a�ĊUk�]��ܴ_r�<���8{mmďҵ�q���~S���d�~6>������W�#"�ṭ���,�"���X#g����������(M��C��[-�k��Ez!����t��K���]ј�9{�@F�;��k+�&�FV�L�th��;�m��Vjs�.��~����Ȟ��C��]�Q�PE�.&�m��6g-ɛ���D��$7���鸝#O�J�Z�a@�i�B��Υ��ۤ�l�h��o��vb��9܏v{��^�E� Oi�=���gN8dQ:ʏ���^��ϳ��6�d����>*$���^�����7x�2N�;����'�o*E����c�ÿj�&B��?����'0xpx�M���- ĥ�+J���~ݣ�q���� �@{��G�铗��ĵ���e��V��iI� �z�M"�_w�)�/D�"1a����I���|�Yu����v�gV�s%ѓ�(G�.Z1�C��~�� +�`(Y������_ �Q����?��u߅#��A��(&���䘨�!%=�@.^W"{�Z\��X~�讈��l2:�S�D��D����VѾ>�H65�� h����D��'�p��9����t�!n�u��73��Ŋ�B}���;�?nQ߉�%J}.�M�%7r�o�E����8zB۹��������d՞��ɠ�cȀ��ǟ�,j����=�%�&稕����uĢv�;Y���r���G��D*�O(Ʌ�V~z��⑥tm���H/���|�C�eC�m��7"��s>���*���:���2��٢v�f5���~f���V��{=ɠ�O�t��@f���3�V�ڷ�ԯYQ�������n���(� y����#���x�k� �t�y>��>�����5}�� ��7S�O|�b�;�����,2Vx��e��s�v�\�o�7�Ab�Ү��_��=Q~%���7F�L�!y��'۷���"[�� Q!y�Mvp۝?�oQ������!�a��~R� M�����N�� J��+�8Y%��W��ڍ��(��q��n.9hIE~�,�N&��}Jk��!���$8��z=�����p�,'8#5L8l`�{�(r>�W_����(�0����j�1�G2���%��찏� /AQ���]H��T�*��DC�|�Ll��ό����$�?})=�Ыv����*|%>�$���|e�I6�Wτ��h AM�*֢��!>�����[A�I`�|�Mz�����dn���蚞Z����b5��w�O��������"�|��f�7��V�K�ّtoR<�!+���.� �W���m��i&|��k2�~�7������rK���Ca(���ܴ_rS�#��o�"?��O}���K}�ov�?����(��q� �>����ф�ɠ�c�u�H��'�5�ߌ�����o�g����/�Y���X����u���(�?������}r�l��V~��?�&9Ytm�� �6��$�h�l�k�k���o�X�E���|���Z]�A�x tR;���ʎ���;��ZY{�ed{�3rp����� J����x�~�wB�}�o��rkO��6g-� ?{��>JrC^��Qm�����ˆ�q`~�܄~h,t����k� T$�<����Ce6;ρi��/������+��|��?3��bO��lN���ܫ������l`V��f� ����[ ?�o��� �Cn��ҷͳ( �^�<��Z�*�S�M����'�#��M7ݴ�`g���`��B2�c�S�."�+����g#!+%C F�����?�"�Ec&�P4��� ��>�7OH9�sX-d-��cx-��:�:}چ��o��QGն�}Jp�hy�p�gL,��n�� +.�O����;��S,�1��J^ڇn�^<}&��w��2���Z�hp]�*�����;�49`\���z�!�P;J��ƃ��H��wKɥOh��O�*&�ߎ9(Y�Ɇ��$r>I]4���~�>�@��1�D�b��L��x��z��9�"�����*�$���gη�̑+I�0�Oi��0F���[|���?�c�=t}��-�V+ �[%���JY$���,�6��:�DvTO�q��;�'M�� ^xa�PP��3�҄�&b@�l��8�.b��QQ����C��'�N+#O�/�|���`��6���M�<��=��s�q�79�������Ɖ}�<W\q��1����#|�����E�� �K�mѹ I�|q�V>��ȝ�!k�@|W?h�l]�+��G}����ؕ-�+G%���܇�ٜ�ky��8���_���@.���d�[�ueum�9�d��)�^pl�?����ڐ�g邽��V����R�ٶ�G_�������wu���7ke�A�^��~���m�7 i��-@��7���CeO��\@s�[���5�\���,h��,�9��ڹ(�g��WjsVɛ-���&��Jrc��.���G^?���=���ˆ����q+[| ��ף�E�]�C�x�Yz���^c��>�l�`��DzK{�?p���s��H�9�����(��\�O�F>�_�J}~$��#t���_��>�ۀ�?l[�f���4��f� ����K�؇����d )J�p E1~�����YQ�O9;�mrV@��j^���#����Mh��&\�q&ȑ��/��%s�'�A�5)z+�qS@B95>�ù D�>r>J���}0&��-X?��I'��g�k�p�����@�P@��J<I14�q#�����#!�$���G��G]9j��B4��`@�����}����5`�-��ϲ ̮�&��`�c> 邗�Oh�t��AEz[���Еd$� N�風����� ��퓟�63 �V s� 7�Ю���$�G��-��G?jϵ���'=�{�$R�._UJK`L0i��ݥ�v5�����1�Ӿ.T+ ��#���>��v_�,��G�m�|��[/�[dG}≏يOz����ȡ���?+���V��Nzh�ęL�KqK ��_�G;�(���O�~�C�W��|#�Հ e봏��?�j�1�O�y,S[�#wQ|�X�C�lµ(�q � ұ�\�O�mQ�����b唣�/���I9��$��Ϡ�V>�؍����|s�I���xۉګ<���b2�%?l�~����������)��J/&��H@�� Y{f���߂I�sl�9 �6��V��c��p�R>�> '�je�A�^-^��B���Qn���Os ���3ϴ�xh����_��M��k1� �y%c��?��9}��YKv���n�� "���j�Ѥx���;�!��$O?c���r�_����%��s�1� ��k�vʱV���5���vq��Q����!B��[)?�A5� ���4��46�,X۝�Z�L���n��������ðuOTHr�,�(�H�J?k p�����B)&I�C�d�,�6gO��2���D,Z͕,LtY��X�B��`�HI�X�� �}Y���� �&����L��E笳�G%}ʆ�FƊ�(?Zm�IRCTHr�dQz�p�=��{�K�fj�bw+�E�d��I���H��x�L��1<iU_�(�x�$ca�9k��a�X��X�m&I Q!y�Mv�E�-O�/����X����1��w�x�ɾ���IC2 [ч$�2�H��x��O��~C�aYhX<�����5����X�yY�m&I Q!y�Mvpk��|�i۶m����N��5��]��NN�iت>$I��"m3�I��T���췭� �'�A2���?�+6/���$�!*$���(�$I҃�!I2N�6�$I�d���I2N�6�e *$��^/J?�E�$I�҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;XW�~��W��r3o�U��[n� ���-�qni���[n�嶺e\�-�qni���y� �Cn�Ϻ��V���s�-��l�Cr�m�[�fn��[n��ns�m�[�fncޢB���>��$ɴ�I�q���$I�$�d\L�q�������<�e���V)�'I2<�C�d��m&I�$�*�d��m&�@THr���&I�� }H�����$I�$Y%�b�����d� �Cn��,J'I�� }H�����$I�$Y%�b�����d� �Cn��,J'I�� }H�����$I�$Y%�b�����d� �Cn��,J'I�� }H�����$I�$Y%�b�����d� �Cn���(�-��I�$U�I�q���$I�$�d\L�q���,Q!y�Mv�E�$I��I�q���$I�$�d\L�q���,Q!y�Mv�E�$I��I�q���$I�$�d\L�q���,Q!y�Mv�E�$I��I�q���$I�$�d\L�q���,Q!y�Mv�E�%��g�m>�O4�]w�ʞ$�ǽ��ۼ� oh���/}�K�>��楗^ZٳuX������7��v�a����v�/~���xG�o}�����k��O�����B'�Ƃ1al��Qc�c��dc�q��ݼ��_�Ҝ{������֏�����g>��{��^���s�ٱ�x�U�h�XŘ1v�a�y�s�E�Kmκ���V����������G>�����_�3[jm3IITHr�̵(�䋠W�f�� ��y~��_7�}�{��/�|e���H?��O6oy�[Z9���l.��v��&P�|���������w-/��r��~�� W����_]7�l6H"���}��7�����&�q�����=�C�Ps��w��W }��׾�}B�쮾�����{���2���������׿���߮���o���76w�qG{o������v����w�}?���5��W����~�����f�=묳�^xa�2����<���MozSۦ}�ݷٶm[��k��ɢ�d�#�o��+{�2� �n}��l���?��6{Qz,|�O�6�5���Qc�c�������y�{���+�eĠo|�+{�Lj���M���?�\x��y睷��ݗ܋�殻�j������~��tl�x��Q w�yg����������c�Y%����/��4X�-�E�)ȭ+W�rr�C9���O~�.w����7ͻ���um`S�d���O>��e�]�ٟ��-�^js֡u{�����Vf���l~���z��G1����$��'��vB܍ �Cn���������?l�v�]q�m!��1K��� ZQ��~��� 7��ʓ��u����j�1�����|ge�Z|��f�v��I���~��͗������W_}�=�� �+��M��zj���iR1�d��"���q�y ���v�m��xȽ8���9��IM��0���?��O+G��}������_lLJ�6�Gq[po�@[p�'�h| �6���d��_�j�Ș(��^\�>J��(P���o^# �*�MD�A�3c��_�re�*��dQz><����}��n��f�=�X��E����6�輷����Г8b �<��s�=ۂH-�1pl �x������9�c�����!�xb��?�����m5,"ϻ���1elyH��lh۟E�*��i��G��q��á�í/9餓��w��緾�H.k��>����k���<xHnGuԚ� sW����6�؅<��w=�[����}t;�9c� ��z��,"V,��A/K��f��=����턚YTHr���� V�P��E�Y0t?]PPԯ�V��νWMQ(�`J�������a��$�}&���p�)�t&%�r�UW]�I'=�x���"1��@V��ԧ����9�&0܇���`%�� }ິ��1k$=X��K����������Ӭ��hU��-Q�'d$��\&�W^ye�;[��*�MD�A�3۱��n��g0~�:�dm(Y�b�?��x�+{C65��G罽�EخEo����8� Փ���ccHߥq���L>��j��!�V�"����(��U�1���"f���4`����#O<��6׵os���~!F)�۲��>���)oV�b��ܜ�ȍ�[�%i/�9kݎ|�|B��ކ�2�����Gc�����$��),j�OZ;Ѣ���<�&;EQ�'����[<���~�X�<�8�@m6i�sz ��:P�0r}% >��Jh)�R ���k�m��*�{hrMHU��_��HL�H�X x�M7�׶�b%4�=��E�L� ����(��c�/���d�� M�U,fu�o_��69�+����?_ �f�8簂R:���{��CI7�k�}����B;�)��4ޜG!��x[�G�>�����@��D����>����,,�]/V;�*2�����O~���(] =��}�Q6��c�ÿ����y��&{|ކ{��ήIi�?���0����V6|�� 4��1�Ԏ���P�wƄ{��LraB� �l�譆���k�E���3���F��^W�z� ��v�m��v�d�s��\Gv��|��GW��:�l�6�0�d�=؉�8D��l�ؘ� �#jc`���+�ϴْo\p���I_�,j�󐥎!_䁼�]�����������J+K�H�Q�C���yV��6 �!�G�9m����~�.�̓d�=>���s���]v���o�<��D&�2�G{�;�u9 ��Vl{��f[y�����?��6e��1�� dI?�#(]�n�Z�tob�g�is�+?е8_���� �����j�@��]|a�o~�I)vE��G�[⩎a�?/r��&-�1�2����i��v�F�c#���m���������ņ�a����>c5)^1?���tOI_��l]D'������m��|�|�k��z�X ƌ%�k��/0����s�T���ØbE2�X�G���]��3GW�8�s�SA�k#�������Q��>ַU6����6�dV�6��XD�O�� �Cn��Q�z9�YR�O�<�� ��S8�(���W���4�zh����pڬR% P(�8������`�s���Fg�˵����p�@��©�\�p� �3��jm��N����J�㩋�B4�d�ǀ�p�ϧ&��O>�.��(�P��I@� k����-�ĀV:�<�|��a!9���z�b(���A�d���k;�h�O�x����f��WJ����ɐ_�.ݵ���֖��/�Dš>�ɏS�DI��Xr� ��3�X��=!���LN9��9Z.ju�볪[�����oIO#Dh�+#IJ��ث6H6�c��bL�8����j�O���Xp=�����3�leL�8FmV[8ζ��?�.lF����qe��_� �#o��3zͿ��zk�����/��N��\�X�=����vsMf}Q���1�/T�S�[i��^�^��b�gR�������O��f��s=Б��/2�wy���O�ȗ�s��c��%�"�9����u �6O�O���������#�x���>� � ��#]d������<��TI�i/�A����F8��� ����W��*���N�|*�2z-yj���B��-r�ڜ�Li+q��L�P�t�/Z�z?>)?(�-+���=����v �k��~�‚�B�+J��>���:.���8����5�������S�ݬV������\kZ���9�t�1灐�mk��,�����o���PDf�� �cU����:�H_#F��T[즍����*��=܋��w��j}-H�zdEMs/�bE�l����J[�'������)��0�_�oW.!��gS�e{\��|���o.��w��f��l;�>�A����CTHr�,�(�d��4}hj�)f�4�d���$���2Dq��� ���i�A�D4a�������~]����{�7�}��!��� ���!*�ZY��Ȑ��7�5�����-���0�{%�H~�z�h�鿧Y+��!o� ��?�G'[����A�o`2�j��Giu��o��]w�5L�������f��WZ��`���+�)�d#[b�D 4�Z���?�q��]�$� ɩ��.=d�o����t��V'�N���� e� "����N�"M:$?a���-1j���;�<��Sܟvh� ?�d��3��n�o����f�O|�Wo/��.H���j��IҴ�#���/� ��G1Qd�i�Ilf�^�߮�)���L��~��j�ئ?4l���:�5���8��h���?�d=��$""��kضy���Qj���7�J�a}8�Q���*��~^�Y("R+�y������u���������� ٧�6��{_k�z����-�m���Z��l���BO$�I�D~���@��'~�po�PDd7�9�+�\��[���q~O>mc/�aC�^���}g�W� Y�׸�*�1F\�>��c���(�9�t;�O���}��ގk�j�x%J��0~�)�RL`�b30wc�5���k��f���_2G�<q�{Y�+"8��T4��i��ù�(���\BD����/~�z\�.� X_3Kjm3IfzNL�!y��B��`�Ei�A��� IM?K��6��B �/�r�A�F�':�W� �8y*��M���JN��)�*'���� ��Óa�dheLm��@Q��H����z�}jN��G�Jm' h���6O�9�>q�-�c;����W�jd"H6)V�B}� ��A]Zaȍ :C{U��+:�H7��J:e�c%65�����Vf�?ɡM��8��{�lW6��?�q�c��E;)���@��� .[�W�K��$��>A��#Ò>E2�����,�;+fj��U'޶���i�jW� �sd��L�z^6#��Ѹz{^_��{�EMf��AL�������j���K�_j?�b+�@K�ϒ�� ����k�]U�8��x�q���S�H%�`��5� ���5�ߟ� >�U �q���L�6�M��K}��؇��A&>��S��b������' �(Oa���J�f!@���66�~Fz�����i����>�m�f��3%��Α��+��t�տ����#W�<-��?�����>*�yݲ _�MJ^~ 6b�6g-�62𲢽�fJ}��>���kɆ�Ny�{�¢ t��R�p�\��aK�Np ����q�{/Ϣc�����-�b�_�U򃲣I����^����z� ̊Z�L���g� U�O";�_� �Cn����59㩡}�9Kj�Yr`��,9��D��I�-Q��x�3���L^��P��O?�t���=JNXO8U�U�`�@�Ε }�� �נo�m��k��]����v^G�|���u�*"��V���Dp.�j Þ��$P<Mf�v�q�5�6� qc|����kn���C��������@���2S@� �q�?[؇ޒ`��O~\�����ϴ#�lX���V+��ͥ�^��U:O�Nr����"A$�$�$�؍����~�_s엕 4��x=여��Y�;M�J�+�~3����kI�^_�K�8�N̦�P �o��3�}���L��}�s&����5芁����T�sIn����K׊�1�q};~�]vYs�-Dz�E$��m*�`��9���5��q�?�*�j� l��<��/�Y���I?l"J��N���Jra�������R��o_�������~ɽt_`���Ƭ��@�����AI�"�7�P8�_�� ��}�T0.]_�Eǻ�K���'��u�����C ?��h�}l�ڜ�ԷHV�9#oQ�c�XA�x���d��|G��29���;���UL~Oa=TQ���6�`���b� �0ͽ<����X{"=�Ndݏ}oGB����򣮶r����y���f� q��r�-�T��]THr�,�(M!��c_��55�, L�4K=�`� X���(9n�xK:��ȱZ�R�G� �zl8{[`�s%C`"�DVנo>1e㉰إ���7�ؾ򕯴�-����2Ɗsl�52�H����=�f,+�u��S� ����v�i;����=\ˮ6��.�+J��Z_�0�{��?.�դ���������~�P�Z�c�m�~$��6�*�]�(Ɏ(��;�q=V��6��V�D2��o$��.9��[�^�Yh��{(�3nѤHDz여����g���( }m�[��VG�&ǥ��2&�p����zX]��@�ĊUk�]��ܴ��������q�MQ�7��5��xh_��H��d�-BcG��`����8۟�P[7[QZ��!����ە�����~C�m~ј�9{�@f��>c@<�^�*���2�Ƈ�����t��6TQ����%9�^z#ʏA�-��e�6g-�-�U�;J}�+1M�*�kɆ]�M< ���\��}�M�Ev嵊�܋��i;�?�*g�G��J�i��Yt����� Ȯ�,JG�t����y���f� ��bD�=����_�B��`aEi�{|37Z�3Kj�Y��i��'��(V�z���:���g9h��.�.%��^�c�r�=�����U�>`��VV|Ǖ?p����_+S�j�� H2`��'=��9* O���d�����.�?���J?�o`��g?k���u$�0�5�kQBg~�����D�V7��2�cdMA�b�ߎ U��ޮE��8i<d��Z҅�-�pM����"��:I�1�\N"�Aa������Yh��{0i�!���S�w���i�&B��P��ׅ��F�{4��^��W(�&_Z)5��(~mVG�V��L�x��z �b�41P��\�����s}��� G�㥸�e �t� j[ d@�ȍ�,j���O��W���Z�g�_IWk�_��w�S�—Y���b�/�����}BI.��þ�3�,�k�0�~Fz\����/�� ��>�o����g ԆH���Z�������ұ^ǣX��=���������z�~Y��@.G�F�c���%����kmJ}�+�:���""}��a����dlQ}f�zL���o3}�xtE��.(c�؇��i��Yd���?�K���� |r�E�Ȯye��.kGB�%K��GP�K���z� ̊Z�L�!����]�����<�&;XXQzҪ�YQ�O9[����q��i����;�b�F����:�H�Ym ��~� 7 xI~Gт����:�����vZ�j��!�0}�I���� Z#S�'����w�}MA�{�62���$�xH�{�H��� gt�hl��hyś������% �)?�؜��V��?p��A8���7|bS����Z_Y�c}W^�_��-����������G��Q�B�;�'� �O���oƻ�vkuR۱�D.�j�{������G���ɢ��j�=d����EIOد��&��O~���C�ة�9MЬ.lFjl�ϸz{���P鞷_�B��im�q��"K/���D� ���ɠ�I���@Q���ܴ����t�>�7;����8�'F3�\�1*�B�}["�t,�H�n��P����ߌ���-�V΢�G��ܦV��>k�<�������v�:6����_�?th���$_ ��?�&9Ytm�+��I/&��H@�eC\�&?�����_�Ԏ}#w%'�r�=�����Z�M:ȱ5:���g�i���TT��6�oBH%G�v⮕�����F��YKv��~\�ρRkƪ6^ED��e��37�MV�!�����k��s)���G�U�_<Tf�����C_+"�+X���9=�s���^{J~0�e���U�U�T��_�VwJ60+jm3I����ߦ�o�ޔ���B��`!Ei4Uz[����ı1�'H���/��uh$7�i�(�OMh�hD��k�g�{ �`#��U%���.���4N��sI� 7�О{�W��:a�A¥��qU�QrœC���KI�� E��k�m��c�u�"Ѡ�|י6s�3�8�=�~҄���DW��ȗ�y�G���'ZɱmO��iU{�L, ʌc05I�}w�0 o%7�3mfܑ-���v��p,:�~��=3>^n>��s�e�ևt�1�ɸz���֖�]��'S��ɏ���$}��i�6��~�᭎r��f;�`?�Q�M�ꉎc�F% ^�|����<JlI4����o%?����GCi;�!YD���r�`����Z��צ�_��۱��}�?�h���k�@L%���s���蛽�f��6���dy衇�:��@��L4�Y>i#�c���3^�~��$�A�.���69�C �Ϙڜ�k"ޟp[?�s���B}��������v���s EL�a���;���aʋ#{�%�Aអm� t ۶�\`�w��õ���F�\Y3��)�����.�����9N9�=�F�Q�A��|�ve'=�#�d;�l�ky�!~p�m/�E��g���veum�-�V���p� �������[��,]�׃�ߪ9_��"��v �q����O�qO�Z�f��~>�9� ��yB�����y`K��� V�i�+��:<��x�>�&ײ���>�q�5״�o��V�p��Ct6��>+�.js֒���� y���c�-c�/��N�+�����W� t��BI_�lX�P�vi�@��Ͽ=�@O)P -V�VC�{�1V�G�y0I^"�mq�r�%�Ԝ��?ڜ_������v$�_�J}~$dc��I[�/� y��m��6�mb�`mujm3IfM)FATHr�,�(�}6�������x*����z�M7���4��K���߱���< �2�{�,��42$��̓(q]��g�{���g���AAp��4�)� (L��N�%�*����6*��Eƽ�����߿� ��BR��M&hȪ�$�X�H���@�Y)�x�4�C@d�O��y��<��&Χ�$3֦jtJp2��ű�ȶm����'6��^�L���cƝD����mcd(9z;��O~���(!��dL&m���~�#��%�VO�#�����c�%��r|�������/~���+�F��o�����4%=a��1&�ud�}2��;�����Gm��An\pA���_o�Qc�}���p;CW�*@t�q��&$�=&�W_}�v�`�$���L��KƜQG��Ud�ï,�X"�N�^g�곷�(O��έN�>���'��f����< ��/�A��kQ��"�A�cѹ� m�ޤ����| ���=����c�nY}�_~���`���>��[�K�� �_�OCOi/�L��v���_����_�-�Od�5i�V��ϭJ/&��H@�� ��%������s@��1� ����xs_V��}��!krg�[}t�qa|t �F���r�7�#���[|��1��b�|���� ���� (J>��c� b��� ����SO=u�<���YKv��^V�Hȝ�s�1�k������'�� d}�jR��g�;�)��u� ���� h����^�6Z���W���c6�u�%�c�;p ��sƨ]�c�%?��Hh?r+�GB6Ƣ �j�?y�=���;���7� 6 �V���6�d֔bD��!7��B���"X�~�GB�Qp �����>�$[�y���*�2I��E�fiR5L@�x�Oih"��J�&��lc,���4��`�HI�X��v��,����8Ca��E�Y��>i��b���4���8��b#��Yg�J�:� ���1Q~�,,�6�����<�&;Ȣ�H ��Ԯ�U�-�4-J�s�=��%)��T8ٜ,R��V�I�l,�6���,}�kҪ�>dQz�?�U����4��8�1yKȮ����6nF���?����E�f�����dY� |���p������]fh6R���x饗���b��fߌ��)^�J6?���y�U|e�,���,B%}�S^���йRO���R��|v�?$��ao����G�G،,:gM�12Vl^m�IRCTHr�dQzD�o���#��κ��ѕ�|;���;l�����^��Y��Λ��+�d�X�mf*�o��Ж"C�m덐��œ�`���q����;ś�E��6FƊ�ˢm3Ij� �Cn��,J'I�� }H�����$I�$Y%�b�����d� �Cn��,J'I�� }H�����$I�$Y%�b�����d� �Cn��,J'I�� }H�����$I�$Y%�b�����d� �Cn��,J'I�� }H�����$I�$Y%�b�����d� �Cn��,J'I�� }H�����$I�$Y%�b�����d� �Cn��,J'I�� }H�����$I�$Y%�b�����d� �Cn��,J'I�� }H�����$I�$Y%�b�����d� �Cn��,J'I�� }H�����$I�$Y%�b�����d� �Cn��uE�^~e�/7�[������[���r疶�[n��[n�[���r疶�ۘ���<���+Jo�-�?��r�Ȗ>$��ƹ�m�[n����q1��ƹ�m�6�-*$��>[����'I�LK��$'i�I�$I�J��$'i��؉ �Cn[�(��o��{�$Ó>$I�I�f�$I���q1I�I�f� D��!7l�-��a�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣt�$I҇$�8I�L�$I�U2.&�8I�L����<�&;Ȣ��׿�����?�n���ַ�ռ��h~�_��g�}�H;��f�׼Xf������7��v�a���Ǖ�I�9���e�����q\�o��_�Ҝ{������� oxC���7���g��}�{�?��ϕ�fǗ�����@��K/��=[Վ���v��w3Ǝ1L�YP������XD�X4}b�O���#�Hs�����-���$�$*$��R������\p���=�أ����璼����m��{�����/n�rvѱچ.�� <��ͧ>���MozS�r�!��-������s�=���>�������w8����������|g��_�ze�*}�%�ѸJ&?��Oډ�s�6�CIg��{W�/&�]tQ;\�=묳�^xa刭G__��)���-oie�����fb[�@�����5���?��+{�dsPc�}bȘ���޼�=�i���O|��7��=up~A9��ꫯ^���ŏ�F}1���NZ����_����1�/�}��_m���k�i���w�MDz(=[�������o���rr���h�Զmۚ}�ݷy��X���o~��s���G?�<��+�����mm������^?���?������?�ie��0{�[��|�;�Y�3,�9�f(J�����Vf��m~�'V=��C�/���A�m&����qəӈ��[ �-*$���^�f�s�ǶF����M��8���o~ss�UW� ɐ����I��F6�ک����`Hjz�<���c�����m����7���ߠ+w"K�B� ���.��}�C�w������oo<��6{�'V�Z ��ɬ �]EQ��]�zW{��\JEi?��^{m{�J��jg�����Q��&GS�/&����[�0Y��[���?��m��:�g���W�v�m��Я+�����曛#�<��!�sL�C�$����Kqu �w�'�������%�A�3��o��m���;~�s��54}�q�uʓ���Rd�& M�$�!�VC�gc�؞w�y��dh۟EQ�䷦�"�{��W�l ���/��3��ڹ�f��y��0����9��>��f�wn ���7���f�a��-�!G����sE���6g��ۑ��O�����Vf��m~4�XUk�I2$�A��;���5�o�������_�r����D��!7��܋�z"��hA�8���j��/���w6���T��@2YaK(���!�l) �1�`v������y���ל~���4G����{�{�����(�^�t�#�hW|��]��R*JG�F&��N,��ه>m�%�fm{k��M�;v%(�'!��W�nj}�&Sz�%�9|���H�djl��?�G�+��]�� ~���6�¯0����ES;��Z�"���WM��>�8�(O"����FK�g ٶQh�w:�����m?ҟ�R�[Ӏ��� ���o�?]y�k�B(͙"�|���}��g�����}��ꫯ6|p���~���?�����X�e�_�\��֬��ڜ��nG>g >!�Wo�[�EĊy��1ǪZ�L�!��S����<��? �Q� �Cn���� v��B�����=<���ەD�  �u2� , T��1�\O�Q�����)O0� Y����� 0�Ͷ�6� �(�.M����������&d���?����������A_IY�1�J���l�7�h�t�}�����W~�:j;��t�M�l�3e+#���ҸF2ѱ�E����S�<ro;6lJHKm�I���%:}�.�t�;�)�,��:���f�և�@��'>��?־4!`Ռշ�?��+�ْ��Z}���uY���9Z����hq]l�����l_g��>�I&���E"�J�i��M�;��0��b�w���e�|�_�_��s�>���:�s���j�m��g�h����΃��"�@�†��$�]���������?��y�L�ވQ�O>��5}��Ȗ��O��gxYox�P��kh,��,u ��|���(v���~t}V`�|1�}��қn��kڍ6D�قϣ�ɏh��p5����]\��ncy�tLD�x�e����$���UȤ&���؊m����Fc�Y��k��mk�?�qZ��q&���#�� sO6�!ҵ8_����u�Gcj� �R����p^$o�#*6���k�C}_�E&��rʺ�I�n��m���<��u~�>蠃ھ����ms����Y�����š��c��9V����I�||����� 3挽�=��B0F��|���[}–�Ÿ�96�V�w�=�Lu/�!h�XbE�$��O�X��XΑO������G� �7�n ��yPk�I2$%=��'���� �Cn����q֬��Zxn �����8j�� ?h=m�3;�c�q����/I��1��H���,�4<�'���Kڟ�Z>9�J��Z�N���eƏ�DI�p��M�A}!�0�G�F@�d��8rR}⨾# �� ������x�+G��TWdF�i�E�EW �|k��@������.�~� �Ċ��+�(��' V&]�㏣�@Y�>1�B�,"�S�yl5j|�&S���'�$^��}$v�i�u�F�D���%=��W�_Jx���'�L��� 6ǵ�/� � ��M^�EW�7���Q�~��l�l�۔��>�8+}Vn�$%��7���[omm����o�i&�\���=���2l� ���eP��؋&��(���W_�f����rN{��?����M�-��̿���g�#+Y���k��$ d�د%�C�I)c`c����A�Ij?�Q����_���EN8�����(>{ȫ�7b�Pޣ<�V>�����ϽxH)��_�t��5�W��쪋���{u�Q�sJګgۻ�X*����tm�A����FlC&���:���5+_��i�܂��8Ɔ1*�-+���=����>X/���� ��#��ɼD6G��6��QS���7���f@�ج���k��︾����\gEM\�6c�!���Α9�������:5��&^q?��u<��F6����������W�73�^\�|�Λ�'3_�v�nj����g �"���9���勥S��5`���߮\Bp?�Ϧ����/מT7� ��<���$���G��]w�5,$���^�V�@���3ϴN�`CRd笨�'�� ��$���$�ؤS(�)��E0 �Dl�L���X,�$h'�" �H�x�Ʉ��K/m����P�X��`n�;h��?�Pp/���� ��\�'ܑl��]�@A�V��;���m�)�M �lB�+Xu��m �X��+ ��介h���c>i���Y����ɦM`ҵ"�nj|�&Sу���ju������V_�~q_t�>,���5�\��"���X����3&��s�uIz��&�F��M�N_�Q2f��?� zm� ��!�K5�V�o �x;'�# ���W���y��2Q$���ԧ�JE [l�ϤoJ��̊Wr ��\������}�4ęp� Ɔ� |+m ���v�7=���� Y1�gbA�)҇I��(F�ك�;m�Pn��C�|��}��a�-�cs}mt?�߬jS�����#59��c�/� �e����ak6�Ե�|�6��Q�?�q��z0,�������~�'�[}���?���f�56]s��?�X]�lKp �(��?���ٷ͠s4v��oGw�Y�_��i�+tHj�"H�m������ %���j��4�J��5�a=��(&�O� � y�Ɔ9��\�q�>I�X��i�eC����y�Ӷ 8�s�� �ݴ����#�eM�@6 ��5���$�F��ډ�JTHr�̽( 8*�~b��x����YS��(qa��zꩶ�$��C�'��g`�9k;�>��CЉ�4� '��+���_���h����۠ Y�<�oN�E�>�d�>���}�5'�ͤ�]�VA���=�� ������>��m�N+jx5��$j'��(��t�(��D�,���ˀ��j2�i1ze)�MH��8lvj|H�{����!��'��~�'�1����K���l�-M�UT��)H �w�Q��ҊC|H��%Ijl3����P�f�K���D�Z�y�BMf��!�^xa�z��y[�D�Oh5i��j_Q�P�3N;������,��{,�/�!W;a���qZAfW�A4�޷�(��I�_~���LD$���y��V�Wȃ�R����O䇁B,Q��]�|�k���ʿ��Ȯ<59eW~�cm�� ȥ&�}%_WqI���mc��g���A�8ɝ�AIF��1�[}����H�����]�vy���_� �v�э���Szܷ�@h�<"CٹV�*��_ƙ�5qJ�M�ˌ>{�)���̽?��<���lX�T���/��e�l>k�ȅ�4���������#}��^�E� O�͗b�_�]�u�ߤ\BD�QI/�� �^d���6�d�������΢B��`�Ei�c�9f��8-}�`���G�c�6���E� ��O�,z�JP�S��%:N�C�-�穇^�#��Z���c������m;��g}����Ki�>��|lB�u]߮(�qo���=6�M� ��&^Q;��6�O������d�]3�6&uB����G+/�Jm�b+P�C4AU"����,Jc�~�'��y�R⮇e�<I$v\��r�~'��A�Jߢ-js�LC�m����[�V���V�|"�ۉ��ˬ��w�}۷��k�*h�W���}������G�9�I�[��`r2���l�>��\���Kn�g��7�+]+G�ۀ�?� ��.k��c�}|�w�w\�DD2�����9�9c5��q�?�*�j� t��<��/�Y��|<���'�t}��+��W� �����|��(]۷/� ���J�i��^�/�=R�+�>�����H�]cc)����$�]���Q�-��}� � ��؇ߵ��6Q8c���,���P�~�2�}��8�d.Y���W�H_K6 ��`��Xq<m�wܓ����S&&��J�KU0fnϜY�k��^�E� O��Y"=�Ndݏ}���i���R~��Vη��?ϚZ�L�Y�C(��KFv���ds/J��Ɏ���-�����zUdj��� |l���>^Eg�lУ��8MR&� ��N>:.r�*��o[�V^Ǵ�X$O�m�� ~5N��/>�����������vEA��[h����ұ�/وR�K�� �"�f�z�CN|z�+�hx{$ъ^�J�&�R���!�����Ҹ���I�q�~񰌷𿌽���u��G�)j���H��?e��~�~�LC�m�����xQ���V�'��O����j!&��+��q|sQ�Lt�M�C��X��z(�`�L�9���mয়~z�l�UkL�i+V��v�Jr�~ɍ��;+�쵵��t�h�o��%x� Y����z�An���H%�h��x �{�q��������0����(M�%֪�W�^I.��r@�����-�k��Ez!�ߐEiV8m�(����)���?��d�56�K�Ky����dh�뺿׍��m�6 �7+`�]����Pğ��gIM\������w��!������4񪤯%t�6���si+�e�S嶠b0�b�Dۉ�Z��h�_�;ͽ<���.��Dz�_n�*JG�t����y���f�� �Y0������%Ur<CS�ϒ�.A0"щV�Z� �x� 7�)��Ix@�!���9�H~%'�zX�?��?��� T����Op���O��ߛ�A09��&��;=�� .��Q������t,�#.Qjs���FH����u .�fW�,�b(��Z$n��A����I � ��G+6;�>��F�A��䵔 ��a�q��F�&z$�$���$-JN�v2�A��� I���6K�X�m��D�-��bOؕ��>�9������i�:�c��(��of��1���L�蓊,��� ��9�w&�%J}.�M�%7|$�ݷݢ���P4�޷�v�g������������*`A$���E ��򲨑�~�b�r7�)�^+�,�l�j��K}�~�#���Rq�|�Ǩ�>�$�[�)>G�O��*L���^׳��t��ˆ�[�D�+�DEn������.��d�>��]J�㈮)���}6�yG�O��G7$��ܶo���}�����R�x�78�����%��g?���@�����#Ƃ�c����UD��]6 �W���-���� m�������'��������Ѵ��,2Vx�_��{�"8�s����i��� �_��=Q~%���������$�����hv�ϊ �Cn����K��d�D`֎���%G�b ���C��'��/&��N���߳b�`D29��q��{'M�`U0A�`��9lP��0��)���J:�����¥��-񒬕ljU���4��)v�w�J�*��~� �c�.��V�0�:�����𲲝6 ��՟Z����a��6$�������K�[�Z��c5�� ��l���d�Vk��&�� �D"jۀ.�p�d@�蛝��ڠ?z��[G��I�ݗ$�Rc�%��6^���3zm�l{®��U� �� Ǯrr��v��_E�m��0�c��)� �O�Vz{�>p�P���H��?���E~�"d_���'�f���6�?�r��!�2F�����ф�ɠ�c�W��ߵ�9U�| �7c�s/�H��T׏t�6q\��K}�~�#��攥?th��Kdc����B�����_s�m�^L�����ˆ�����,��!򶹴�$Ú� h������r �G�i��3J�6��� ��7���f�|l�´/��7S��֮fAm�Z�~�c�}�|:3��ƫ�H_�l;�|&�~h t����kݸ���G=C�#�����e�{y�ˢbED��s>ש�C�~�#_�/]�^�O�H/k�%����$C��E��wľ|�JTHr�ܲm�Eij��^{m�ǎ��-�n��~�/A���$,�ï�զWg�'�<��I��ȁ{�s�"AC�: �8d�����:eݏ�܇?fG��w|S���z �� T�,(��DpMV4� ��[}Q��8���$[�! �$�B��?�O}��d���D ���@���, �u�Q���/��t��6�OBFM{ ����ƌ@���fL_u}�B�hm��� ��l�7��Q��#�b:㈳b�I'��ޛI:�T���J����L��x����#�l_I��ʔ��Z=�=.�L��ezXeу l]E�)� _ Jm�/�x�f�Qz|�ᇯ��P�LK�mF���ƋR\U�$.b�|~{®�a�[�E�/��\q[���W59��_x��'oO�?��6����6l��M ��Q!���VbaǴ��ȣ>O;�$6R�!�#i>���ܞ{��8dg��PĤv�o�8��������~ ���@អLjH�%۶�\PD�|q�V>��ȝ�!kƒ��Gwl1Uק����8�����G}����ؕ-���\�ێ�ɶw����(�ksOl��Jf�Sy� �������[��,]�׃�ߪ9_���� ��]i��6�����(�@�����t�v���>����m��8������l�� \s�5m�yk�밐�h����>uQ���솟���ȏ�-(���h���N�G^?�]�����]I_�lX���b��,�Ҹi��\���]<�,=��s�1Ɗg�}�}�B^"]��y��v�������)���\����H(�G�&mE��3�����oo�$������i���$�.��l�o��GQ!y�Mv0��4��H<I0~� AW���~�/�M<�698A��?�(DJ>{�Gs�wl�)k��?IOQq�zr�~�}�q�Lt�m��^���TsR_q�* ��},%eJ���B�جJ��:�����]q ��� Ȇ~S�"�"d�q��Q�S��g,�6Y(��mP���'�l������^�۴lR�o^�c<��imS_��a��.��f7�!�z�����Ml�k���K��G�+��W"gƋqC���u�]�f��dH��a�q>)J���B~�~`3�>>�[j�Gl(|H������A�mF���� t;���dt[���3�'����w�?����o�C���c��Fc0nQ1Q�D#�T\c\0n��J4j\��D�����0�0��� ~PP૸����:��tuMսu���t�땼3ӷ�=KU=K=��i&�� "�9�=����� [�����W�2���q!_Y�����3�X�� ���Ls2Ώ�D\�I��[�E�K����#�>��s��cɷ��G��>M�O���ol���9��$>(�Ai���P`��J�^��O~��Y��J�ȿ�+�>el���9�O�ڿt������n��0[r�R���Db)��u��%�'�w�e����yҾ乩Ƹ��J���܆R{F�o� ��L�>��*��X�Z´�K���A�E�%�An�!�M��q�GچA��f�mg=g���6�@?P�,>���%:ԯ ���Q(�#��bM}�$ZsVγd7���9�:���c�E�^�4׉1�⏦�+|�����x�f�Aģ��6,���J��y�#篊��޹� f9�c6�~ӛ��b���;i�_��n���i�Z~D j��?~���[� 6 ���C�m� I�c���'� �C*�`)E�e�U�S�hɘCy � 0q�x���lf�!"�d��Y�T P&��4b"V*j�Ɓ�.+���R�l����Cf�"� J�ga��`Q��Qء�F�m=����-�b���fa��v ��²s�E���xʆdž��L)?�(,�6EZ(��T؁Ei����J�=�6[R���D�ǣ���q�L�܈E(Y>�z�i��f���������|�+���|u�z1kn;�s�ƲsV��0+6˶M�J��!v@Q�J��""m�CD��2m�"���n�w~�9������?����Utb+6/˶M�J��!v`QZDd�!"�d��iJf�G�y�"C���N �G ca�9����0Vl^�m�"-� �C*������ �CDƉ�)""��qQd�h��(��T؁Ei�Ї��mSDDd��8�6e#P*$����""3�'ڦ���*�E�q�m�F�THRa�EDf@"2N�M�U��"�D۔�@��<��,J��̀>Dd�h�"""�EƉ�)�R!yH�X��}��8�6EDDV1.��mS6�B� ;���]�EDZч��mSDDd��8�6e#P*$�����<�б_nf�V�V���҇(5Ni�J)�Ԫ��J�Sڦ�J��!�9�(�U��+�ND���)mS)��Z�qQ�qJ�TcV��<��8}Q���[����̋>Dd�h�"""�EƉ�)c�THR[�(��o�⻈ �>Dd�h�"""�EƉ�)�R!yHah����u��bЇ��mSDDd��8�6e#P*$����""3�'ڦ���*�E�q�m�F�THRa�_�Ӣ��H+��q�m����b\'ڦlJ��!v`QZDd�!"�D�YŸ(2N�M�� �C*쀢��,J����'ڦ���*�E�q�m�F�THRa�EDf@"2N�M�U��"�D۔�@��<��,J��̀>Dd�h�"""�EƉ�)�R!yH�\aQZD�}��8�6EDDV1.��mS6�B� ;�(="x���/|a���}l�Y$۷o���G�����r��7w�|�+�;v�?� ��c�"�������޽�-o���ec���#�<�}�������7w�ӟV�Z����u����'=�I}Nq�)�to}�[�_����󟕭�2��V����F��a1�?�֜ն��lŹ�,�*��-�V�Y&�B� ;8Z�޳�E�|���'?�=� O���t���{G��z�����[n��{�;���ܹs������������ԧv��~���)�0�k_��}lߖ��vZw�5�������{���}l�Ŀ��ԧ�?��+[��s ��t_��׺�<�)�w_�җv�_}9�s�\8'�����я~�=���+[eZ��{�\8��6h��Q��E�����z�Y��$n�����O~r���������K_�ұ~}�3��]t�Eǵu+�����?,N�;��tۯ~���>6+�>�6��������M{�������'�[1��G�m囗 ��9�yN�o��}���}�[�Z����c�z��#�k ׸��{W�j�X��}��Ki�SO=��ꪫ��TJ��}� _讻���/���g��[��,v���W_ݽ�/����? ^�:� y߇?��^C�`��ϣy�ռ�3m���|��X</�O|������+���z��������?����}�Ӟ���ϋ̙[s֡��2���Ԇ�2[e.��G�Ī|.�hZmSdh�m�qə��QG|ӛ���u�]+[�X*$���u/JxYABBB���+�싪L�n�����G�u�������j:��J�k���;��3�I$�2KrJ���w���W��Uݥ�^ڋ�<餓��~��k2mK�� /��?>��3��O���Ε-�/J��O��������Nq��I�Rb[�묳��~���}LQ������X$s��� �$�#�Hq��n�i�~[H0&��t����g?�� ��8��I0��q���ʧ��=я��H�7�h�vx�{�ӷ�����~��o|�k �1�H��?���^>�я���/�\���@�)�ml�6�=��Dd��VIDek�b����;�p�&�_��׻w��k �G����w���oW>���1d�*����E�G� �;�>��M&A���ŧh�!ϭ�e�����eA�ҷ�0`h�:�C�o�E<�o���+��8=�P�~��"��}��=���i�㐏?�y�;���M@����}C�k�q��k����/̎Zs�Yڮ�s��J�5���V� ��јcU�m� ~�?�A���=��I��}�qG]�ȑ#+[v} ,��T������L#�� 򒗼� �"h�N�9 GSY�K�m�$�&�����?ϒ�r7�D&/�r��{��ޚd��sטd�{�^;?�yzW�kO��{����,�H�(ؾ���W� l �$\� �0&yl�Ǫ1d�LJ�Nt�0D�]i�s�9�{ֳ���� ��=�֬V�;��iĊ���<�@�#����/�L��1�j�ۋ��e0�)��-� =Q�*��lmZls�\�;�L�AĆ�O�W�tϚG C֋!bl�����{�{��֬r,Q��C�[ ����}�˂1��MaC��б�̗�1y��(�� m�=�<��:� _��A�+���#�qc�4��ײ�#�欳�]���'��kn�[��0��1ǪV��z���F������ qc�THRaW\�k���\8+]_���u��_W>= �����^'�7 o�E-P��}��w^�1 ��HN���� � ?���"s�ݔp����׿�5�!�/V&�x��4��XZ�'h�c�V��GΙ1�R+��h����x�6��}���D����?��LH'�q�C�_ks�<��c�/+�KE���!���� џ)��xc5���n��m���>��������wM��<��i_���&�)�m[�h�f�ՇL۴96��L�bi��*��F7�8�~\�������2���3����"i���7�x���!���]��a!l��+���M?���O�O�xb�V�~�R`�\�҇s`� �Y�%�����\n��7��������ui�Đ���s�=w�5s޴-�� .�} mL[�m��b�)|���m�1<e��ؒ���������D�:��|F�R{Gu��8�Z��ş��'����s����}����7q;��x�O_�9ɴ�o��I��'�YH�7�L�S��in��{��JۅmjEP�2�f�ھ� ��k�?�������x����<i���S�:��`,a��sf�U�eV�Z�|:�k��Ī�ȋ���쓹m��o��u���O�����.&��K>-,�}y��-�'�1ſ��5g���ߤ~��q���P�9��wZ�Ѵx� >���S�� cO��2���ς�Ӳ�Ç�6�-�/V`�5 �׷m۶���ƌ1Ŋ-���O�k�v��K�ӚK��4?�q��]v�e�����m1��6E��6��#ƒ��Õ �C*�`]��iҚ:]ȃ����:� ZrR��xU��ȋ�9Q8�1G���cqgg�>�w�X�]�\Z��a@�d*3��-/�'H��˃X��8���I�Ǫ}���¹��ly��� ����f �J��(����gL^Kc=΃�\����+��?}ߧ���c�h�I I�"�a��j0~�U��.�u8�h+ڏ�<}�KJ���{��V2il��+��c�0�"�ӧ�Zg���ȷ�m��Q�Jm�B�;�""c��6�7)D0�v�>����d�B<�8��c%?S����/���W��g��� &���K.���X��l�~)��%�gLf�t���|z^��XEN�� �ϱ��O�R əv��K�����e/������O�+�)i[��� ���?G�16�s����$�������I+�9.1�I�>����'b���ê=�[#�.����>�u�wQf�c���g�T�qÿ-9IK��5O��I��'��P��8�����xz��'��Q�`\G{���>�=�q��b�|�6�\#v�&�h��ߟ��ôx_�[i�L�~N�^� l�s�m��crV����ĥ��jW�:�cwZ^ל���b���O��q���c<���2�|j�tR�G��CҚ��ئϹ!�����i'�~�G� KPDF��m����+�� ����knÌ5�5�7p�\;>?�_,��X�w��}O�ҿyߥ79�9V�bE�_��[���ϓK��Gq���7c����u��'?鷃������6E�|��_���R!yH��E��֩(��(�U��r�\gD�s�zHd�8��x%��w I�"c8�4 �H�bw�K�+`@��2��^IB��W��w9ד^#D�����L�k%?V��X��{�K�.�@����ڵ�� ����̃�����5��B���"V"Ӷ$,� �&%�|cl����,=`��m�S-9�ۿ�]p"�5vZ}�^�1†s���?�0 ��>������A�z��_q|^���DL c܉l$Zl3|s^���ELj~,�W���1&�1I�H��T�_V~M�����Qd�{��#N1�L�����{z�)�R�vͬx%>�+����M���� N��k4��  ŧ�~�����9΃���]���!ڪ��\3��4晴���s��N�ᗣ���>�_7�"F���=��?�6-9Ik��bW9������'ϵ�. |6���6�N���d�����yz�;-���Z�Al7-�6j��%�5���kß�G��Hl�R�-���)��Ol�ڧ5���a:c��c��q8��+�s�[���C kī����֜5�vz�h�<6�>�s;n�G�ī �`>^K6�-��{|��andp,nhп��`ߌ�ԇ���y����JC�(�� �<��|�Q󗭹DPʏb\�w�q���oz�9l �Ǣi�M�E�"���CJ��!v��Ei��S������y�!�<��>wR�d"(�9��0����� ��z��3�߱ ������Ӎu�+�.}Eߤ�*&�܅e?yP���}���'�]�.O�r�k��L >��"�q��d6��\J�H��� �?�� ���8 �_�M��8�h����k� ǒ�iΙ�G� OX�h�s��y��F�Շ�l�~���ݯ�`�L ���#���HӤ�֧�����jc1_}!��h�͒o�*+�R�����;R�M�f)@�d6�?��_�Bl�W��D,ϟb�H���=�8�Z )Q��h��1w�ϣ�hג�:�9�.�tU��1�s5j���E�1Ҹ^���1�C��h�BLZ���)���C�������k�\�������3O(�\��w��{n�@��E/��|<p�W�XX�7����u������]����K~k��C���'�c�6a���dlQ����)��i��ӛP� mv�:��c�6�-h?�P�c2��)\;�4\�9kmlS@�ۚ��m��h�4K��)�ך �yF��qϵ�b�>�8�y��cڅq�-��}p�6�u���y����X��� Z�5;_6-�J�Qm\ח^?�+���h�M�E��'GHm>�j��<���\�4��SĹK��*9ơ��:k�/>ǁ�Tr��7-�C�)����Y)�B���o~�'Cܙe��Q���\C��$�ϣ]�a�" K�?�A�]8F��<֓* �mM2�oǝRnl���PJ�`R��EJ�>�� q����#'��M �K�N:�O;�$/�W��mҵ���1�6��kɷ�L���=�b.l'�ß�O�?�TO&������ϰ�+yM�?~WJ4E�N�m�|3������J�6�~?���Č�?� V��v�i�7����C-�!b��K7,)*S��8�&��sW�I1$�&��j�\k��<ڍ����v�}�����~��?� ���}��_c�qx�����>OM��9�6(�[�(�31g���d�_K��v���V�m����R{崶���}r���zJ���(p��Wk>�ہx��C )�}��W� P�.>�v��,���>����u�����q8v��2��Om얮�ܙ����mac���-s�b�O��~���O�:��Y-_�5^���4]�9k�퀟s�)�m|��.�6��,�*�4^k6 �s�����=���8&Ǐb2�{�Ą(�28�(3&�٣p �+�q��X��� jv �.�q<>K)�2��ӱZˏ&�+�O�'�yѴڦ�"!���dW*$���u/JC�GF�_��`ܹ�h�H�Β���T(E���;7��s�9��<�2���>���>ZړG��Wz>� �1㏺��|�3�}b��`�m�WX��v�=��͠�v���y`J� e�?��ZP�|j}���h �)� (��y���N�L�����I2��pn�O���+�c$��}��wJ�w�6 �>��Z��� ��/���>��?�}�W�O�S&9�$3{��ȸ¯X���H�m�|3��ϯŝ��͖b��W 1��XŠdb�PLPk�W���MИ���R�i&��b��8��ӓHcH�C� j�v�ϣ���Nn��;Ċ�ھZb,�MQ�'Shk>G����Rh�����6�����; d<Añ�~li��.�ڊ6��R�\7[Q:VcY�f�����6�����J�"�xC��x_�Y�������>����G�Sj�S����K�UQ8� �-s /"?�xJ��c$��bN��lM�M)H���nz Ak�Z#���M��k�vj�G0O���ך c�s�1�7�˹r\� ��t�u�9��8wbq���x�w�?�s��eNJ�V_P�S�?�k���>��� >O�j)?�I皏���E�j�"�" Ҽ9���B� ;�����_�ΉBm$��d��,9? p�t� V$S�*ݹ�9��<�r���H��=��f"}�Jk�J�z��4�r^L�$}�`ב��cA-0�@rX*�N >��hc �LvY��*�4ؕ�`-I���}��;��c.ybAO��mxĐ�%%�+��QT&iJ�x�_|��Km�OZh3V3� !$��'��l���CZ�6�c1�_�x �� Q�/%���bJn���H|��� M�m�|3��ϯŝR�� �;f�~�mS�"�8=�F_�r�X[�wfB�v������l�!%j�\k��<� ?D2��{J�� �h�s?ǹs�����]tQ���q���V��ڠ6�J�\�3�hiȯ�{"�>m�IZۿv��y>FRZ��{K7L#�J�>��.|��_�IJ�}m�Q���,� `�?�m�� ��K�7��o�{Y!Ν!����~j�����y�OE���g����/��^ziu����[��3�<�{���v�kmh��O?�;�s�?����s�7��O����Mk�Z���� ��� �|@�?�Z�U��x�d��ʻ��Ÿf�,�Ή}�|��_<v�� ��c#�+g��"��k��o �F��9/�/�e�G[r>��j���g%X��)��oJ�t�D��<������{�W�Ƒ��)p �+$�<י;�G���{�:t����jwnkN9>O�2m���|�=���18~G�<LQ��!��FXjA*���)��r\�;΋" qi`h9D䁩�Xy�?HA�|j}�T쓻�3ל�E)�Ҍ��B.1�?�ɸ`|�IM@��q��瑂M�Ed��կ~�q;V���N�V�92��<�T���78��� ��"�p�2i�!�c�D(���Ӯ�/`�<���u��h�&b,�n6���۬MP������Nn�6��c�Xb?v�O�7���$A>�?�9E�;��� _�o�d0��5�����Z����n)&�����%�,���|�SE�L�1�s��>�7}������Q�����Q�P��ڠ6�J��9ǓO>�����>P�n�.+i��1�%'im��5���Ii�O��7���:L�h����y�~\7 ��Rb�y[��i��4~ >b��d�|��.�����5��j)����N:ija��>�M)�a,��?F�~���)�9P�þP~#����xHN�w���֜�f7���M�s��Z�Qk�*Q��lh{ ����6����xͼ8�"y޿����ļ���Z�+J���_��|�Q���\�c�^��2�?m�?L�N�E�m� ~���K�I� �C*����P�Ƒ��;֬4�!Ɲ�E3�u��/% p$��\rI�����]� /�pMp��D��Ss��y� r�V�0�h�hO�<�!D@�8O���(`��<��}�B���JI}H_��U�Wz,Η�^|�c�V���S� �h;�̖�c<�:�c1���x�$��G��S��Z_�Ĺ�__g�m�Im)9��Y��y��p1�!����IL$$1��w��O�s~���HH�8�y�X��� �;����2$I�~��q|7��f�Շ��F���_��?�T�=}� ������+OD�g�7��7����,�f��S�c���Uq�̸)-&�� �� �Ŏ�>����Ǧ��q���b{�n|xL��_����pr�Yޙ �`;ޕ�?���Crjq2�u��@|~.b"q�"�>�v����oy�ѦlC��H�1�s�O|F~F�}�n��6 G���<��=E� Jmc)=��w����9��8��>�u��쏶�/��<�>r ��O�I���K� �y�>�J��-� ��m'�)=_�WO�ZL���&ec�[�\�Ͱ3 ��m'������<��ܞk��Z��6O����c� �s�֕���$w$g����}䊜��>1v[�zV�깖󳿖9Ī�� �X[:N��s�UWU��c���5�yM��1����w���,���.���=O�5g�|Kv�Ϲ�0>K�X��8g����e1k�G'���<^�ތm� ��:Ɇ�༈�i?3���sb������b<�nb�r�1� ^�ʍI��_��[�5;o�%��<? "1���+�qF{�� ��;��������kO�M��6E�$l��8l7W� P*$����W�wQ:���"%p�$2C0�u��/g�uLqpL$���5i��F"V{������)��;v�h~����w�ݯ�?����>`����M�p�$||�㖎�}���X|�Bj�X���h���6( �%��9ڊ���֯��CN �������'h$�<&L`����#�W$�`��b�r��c�L0��ڝw���0Vh ޡ��S��\�f8�HNR�cs�}�xQ�ٌ������������ l���g�я��yR�~r�?IlO=�����!6I��F��6k�9>Om�� Un�a[�"���b��zcB6��K}<7�8�/������Ï� 1��D�$� >?�G���|eYN�"G���5����T��iI(�!�%�K�!��GL:��s��c�ϕ�G��>M y����ؖ��ҸǾ"�JmPc��X8�Rn��>�uG�a�;����y�N�IR���!>Oۇ� �͑#GV>�-?Im�t�y< j1�ϣ�b8m^�}r~S�Ĵ/�[j�1.�������<���x_�[0��l[zP 9c)�c�"kmN��3I�����,y=yS-��q�5M��D�9뀽���$}Y��P\3���r n�p���(\mϓ�-Y��Bk�Z�~��b�-�.�xM�w�q�O�Xf�G��>߁��x�f�Aģ��6�f��Jc��`���%Vz���r�1� ���ߨi����;�\�f��n���i�Z~�m�u�Y}�>΃�����?~���a��#�}�ǿ�"69��)2$a?���R�T*$���_-�(�L��u�,���_�'$��A�͆>Dd�,�6'ON&�L���1+�撍]V�їy!x^����Cf�"���,�, �7 ;�(��ô�nZ��a�9��Qm�e�c�XQ��m�m�"-� �C*�/J�`QZD�h$��j�͂>Dd�,�67bJ�O�cxڪ�Y�(�|��?� 9VX�F�^�'�a�9��h���eۦH �B� ;���{,J����'˴M��2 � ���SE<?���@�²sV�щa�ؼ,�6EZ(��T�E�o�gQZD�}��8Y�mZ��Y�s��I�!}��XhX>� ��Y�G'��b�l�i�THRaWY�iG"2N�M�U��"�D۔�@��<�����6_�!"҄>Dd�h�"""�EƉ�)�R!yH�\u�Ei�f�!"�D�YŸ(2N�M�� �C*쀢�5�|}��H��q�m����b\'ڦlJ��!vp� {-J����'ڦ���*�E�q�m�F�THRa�EDf@"2N�M�U��"�D۔�@��<��x��Ei�F�!"�D�YŸ(2N�M�� �C*���m��k�[�iB"2N�M�U��"�D۔�@��<��������E�|��/7�`�\�Rjx�C���M��RjU�E��)mS�Y�B��P��n{R��*���R'"}�R㔶��RJ�ʸ��8�m�1�THRq�k�gE���J)��RJ)��RJ)�ԉ�XQz�~��J)��RJ)��RJ)���A_�}w��7Y�VJ)��RJ)��RJ)�8Y�VJ)��RJ)��RJ)�n�(��RJ)��RJ)��Rj�5��n��ݰâ�RJ)��RJ)��RJ�*-J_��@{Q��Ỻ]�o�����a�-J)��Rj��|������*��RJ)��,���;X)�P���{�IIi¢�RJ)�6���Ky�RJ)��RJ�hMQz���Ei �J)��R[[䃥<Q)��RJ)�Z�Z��izQ�G6K��RJ)���<�RJ)��R�*j����mӊҮ�VJ)��R���J)��RJ�yu�(��@�mה���P)��RJ!��R���RJ)��R�5�m;t�w�lQZ)��RJM�Ei��RJ)�Լ:V��u�۾{JQ��w(��RJ)��;�RJ)��R�j�(}��qZQ�?t��RJ)���P)��RJ)5���w�n�s��4r��RJ)��֖���RJ)��R'��Ao�}�۱g�Jit�]�Z�VJ)��ڢ"$,�J)��RJ)բcE�=7w;v7����&����RJ)����y���PJ)��RJ ��A߸��ng��;�RJ)��RJ)��RJ�y5�{n�v�բ�RJ)��RJ)��RJ��)-J�(��RJ)��RJ)��Rj�:V��{k�s�Ei��RJ)��RJ)��R TԠyuǮ}�,J+��RJ)��RJ)��Z������E�}�Qu��J)��RJ)��RJ)��{�{�XQz׾[�����y�NDDDDDDDDDDd(����[-J�_)J>rw������DDDDDDDDDDDN���?������ێ������s���Q7�zg��;��{���l.""""""""""2�o9tg�����G�ҷu�ڹ�c���{{���|UDDDDDDDDDD� j�����~Etԝo���n��C���}���JQz�#�6PJ)��RJ)��RJ)����;������*���}o��k�m���w����RJ)��RJ)��RJ�u�n���� �����G�ҷw���z�5�cIEND�B`�
337.471429
2,746
0.275957
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":null,"auth":"Logged In","firstName":"Walter","gender":"M","itemInSession":0,"lastName":"Frye","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540919166796.0,"sessionId":38,"song":null,"status":200,"ts":1541105830796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"39"} {"artist":null,"auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":0,"lastName":"Summers","length":null,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"GET","page":"Home","registration":1540344794796.0,"sessionId":139,"song":null,"status":200,"ts":1541106106796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Des'ree","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":1,"lastName":"Summers","length":246.30812,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":139,"song":"You Gotta Be","status":200,"ts":1541106106796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":null,"auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":2,"lastName":"Summers","length":null,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"GET","page":"Upgrade","registration":1540344794796.0,"sessionId":139,"song":null,"status":200,"ts":1541106132796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Mr Oizo","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":3,"lastName":"Summers","length":144.03873,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":139,"song":"Flat 55","status":200,"ts":1541106352796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Tamba Trio","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":4,"lastName":"Summers","length":177.18812,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":139,"song":"Quem Quiser Encontrar O Amor","status":200,"ts":1541106496796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"The Mars Volta","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":5,"lastName":"Summers","length":380.42077,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":139,"song":"Eriatarka","status":200,"ts":1541106673796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Infected Mushroom","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":6,"lastName":"Summers","length":440.2673,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":139,"song":"Becoming Insane","status":200,"ts":1541107053796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Blue October \/ Imogen Heap","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":7,"lastName":"Summers","length":241.3971,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":139,"song":"Congratulations","status":200,"ts":1541107493796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Girl Talk","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":8,"lastName":"Summers","length":160.15628,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":139,"song":"Once again","status":200,"ts":1541107734796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":214.93506,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":9,"song":"Pump It","status":200,"ts":1541108520796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":169,"song":null,"status":200,"ts":1541109015796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Fall Out Boy","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":200.72444,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":169,"song":"Nobody Puts Baby In The Corner","status":200,"ts":1541109125796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"M.I.A.","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":233.7171,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":169,"song":"Mango Pickle Down River (With The Wilcannia Mob)","status":200,"ts":1541109325796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Survivor","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":245.36771,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":100,"song":"Eye Of The Tiger","status":200,"ts":1541110994796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"}
475.8
531
0.697805
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"N.E.R.D. FEATURING MALICE","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":288.9922,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":184,"song":"Am I High (Feat. Malice)","status":200,"ts":1541121934796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":0,"lastName":"White","length":null,"level":"free","location":"Lubbock, TX","method":"GET","page":"Home","registration":1540708070796.0,"sessionId":82,"song":null,"status":200,"ts":1541122176796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Death Cab for Cutie","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":1,"lastName":"White","length":216.42404,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":82,"song":"A Lack Of Color (Album Version)","status":200,"ts":1541122241796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Tracy Gang Pussy","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":2,"lastName":"White","length":221.33506,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":82,"song":"I Have A Wish","status":200,"ts":1541122457796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Skillet","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":178.02404,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":153,"song":"Monster (Album Version)","status":200,"ts":1541126568796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Dance Gavin Dance","auth":"Logged In","firstName":"Marina","gender":"F","itemInSession":0,"lastName":"Sutton","length":218.46159,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1541064343796.0,"sessionId":47,"song":"Uneasy Hearts Weigh The Most","status":200,"ts":1541127957796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"48"} {"artist":null,"auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":null,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"GET","page":"Home","registration":1540829025796.0,"sessionId":170,"song":null,"status":200,"ts":1541129561796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Dalto","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":190.40608,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":170,"song":"Falta Te Dizer","status":200,"ts":1541129674796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Kanye West","auth":"Logged In","firstName":"Makinley","gender":"F","itemInSession":0,"lastName":"Jones","length":278.88281,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541091973796.0,"sessionId":118,"song":"Family Business","status":200,"ts":1541135741796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"17"} {"artist":"Jason Mraz & Colbie Caillat","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":189.6224,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":187,"song":"Lucky (Album Version)","status":200,"ts":1541137949796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Liz Callaway","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Koch","length":175.43791,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Journey To The Past (LP Version)","status":200,"ts":1541149281796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Decemberists","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Koch","length":242.59873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Everything I Try to Do_ Nothing Seems to Turn Out Right","status":200,"ts":1541149456796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Kynnedi","gender":"F","itemInSession":0,"lastName":"Sanchez","length":null,"level":"free","location":"Cedar Rapids, IA","method":"GET","page":"Home","registration":1541079034796.0,"sessionId":88,"song":null,"status":200,"ts":1541149530796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_8_5) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"89"} {"artist":"Christina Aguilera","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Koch","length":254.48444,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Impossible","status":200,"ts":1541149698796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Koch","length":224.67873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Secrets","status":200,"ts":1541149952796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Kynnedi","gender":"F","itemInSession":1,"lastName":"Sanchez","length":200.202,"level":"free","location":"Cedar Rapids, IA","method":"PUT","page":"NextSong","registration":1541079034796.0,"sessionId":88,"song":"Wild World","status":200,"ts":1541150017796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_8_5) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"89"} {"artist":"Brett Dennen","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Koch","length":179.66975,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"World Keeps Turning","status":200,"ts":1541150176796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Godsmack","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":5,"lastName":"Koch","length":208.24771,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Greed","status":200,"ts":1541150355796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Anis","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":6,"lastName":"Koch","length":246.59546,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Swing Javanaise","status":200,"ts":1541150563796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Tiziano Ferro","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":7,"lastName":"Koch","length":251.42812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Ed Ero Contentissimo","status":200,"ts":1541150809796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Kylie Auldist","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":8,"lastName":"Koch","length":265.92608,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Ship Inside A Bottle","status":200,"ts":1541151060796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Benga","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":9,"lastName":"Koch","length":286.17098,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"The Cut","status":200,"ts":1541151325796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"T. Rex","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":10,"lastName":"Koch","length":132.85832,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Ride A White Swan","status":200,"ts":1541151611796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Mexican Institute of Sound","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":11,"lastName":"Koch","length":278.04689,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Mirando a Las Muchachas","status":200,"ts":1541151743796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Velour 100","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":12,"lastName":"Koch","length":202.29179,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Clouds (Of Color Bright Album Version)","status":200,"ts":1541152021796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Maria de Barros","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":13,"lastName":"Koch","length":276.29669,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Riberonzinha","status":200,"ts":1541152223796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Toby Keith","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":14,"lastName":"Koch","length":177.162,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Big Blue Note","status":200,"ts":1541152499796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Marques Houston","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":15,"lastName":"Koch","length":264.98567,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Naked","status":200,"ts":1541152676796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Commit Suicide","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":16,"lastName":"Koch","length":105.482,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"In All This Revelation","status":200,"ts":1541152940796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Smile Empty Soul","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":17,"lastName":"Koch","length":218.61832,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Bottom of a Bottle (Explicit Album Version)","status":200,"ts":1541153045796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":18,"lastName":"Koch","length":221.1522,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Wake Up Alone","status":200,"ts":1541153263796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Eyehategod","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":19,"lastName":"Koch","length":155.66322,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Sisterfucker (part Ii)","status":200,"ts":1541153484796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Sunidhi Chauhan \/ Anu Malik \/ Jatin Sharma","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":20,"lastName":"Koch","length":319.32036,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Dekh Le","status":200,"ts":1541153639796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Blondie","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":21,"lastName":"Koch","length":127.73832,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Little Girl Lies (2001 Digital Remaster)","status":200,"ts":1541153958796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":22,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":172,"song":null,"status":200,"ts":1541153985796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"She & Him","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":23,"lastName":"Koch","length":167.83628,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Got Me","status":200,"ts":1541154085796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":24,"lastName":"Koch","length":294.76526,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"The Lengths","status":200,"ts":1541154252796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Survivor","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":25,"lastName":"Koch","length":245.36771,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Eye Of The Tiger","status":200,"ts":1541154546796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Conya Doss","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":26,"lastName":"Koch","length":317.98812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"I Miss You","status":200,"ts":1541154791796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":27,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Downgrade","registration":1541048010796.0,"sessionId":172,"song":null,"status":200,"ts":1541154854796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Disney Studio Chorus","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":28,"lastName":"Koch","length":234.84036,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Little April Shower","status":200,"ts":1541155108796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Dirty Projectors","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":29,"lastName":"Koch","length":319.63383,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Stillness Is The Move","status":200,"ts":1541155342796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Boom Bip","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":30,"lastName":"Koch","length":330.16118,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"From Left To Right","status":200,"ts":1541155661796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Avantasia","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":31,"lastName":"Koch","length":368.97914,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Shelter From The Rain","status":200,"ts":1541155991796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Amon Amarth","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":32,"lastName":"Koch","length":312.29342,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"North Sea Storm (Live)","status":200,"ts":1541156359796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Young Money featuring Lloyd","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":33,"lastName":"Koch","length":196.33587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"BedRock (Radio Edit) (feat.Lloyd)","status":200,"ts":1541156671796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Breakbeat Era","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":34,"lastName":"Koch","length":326.32118,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Anti-Everything","status":200,"ts":1541156867796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Local Natives","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":35,"lastName":"Koch","length":237.92281,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Airplanes","status":200,"ts":1541157193796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Gabriella Cilmi","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":36,"lastName":"Koch","length":207.38567,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Awkward Game","status":200,"ts":1541157430796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":null,"level":"free","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":165,"song":null,"status":200,"ts":1541157495796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Minus The Bear","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":219.76771,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":165,"song":"Knights","status":200,"ts":1541157631796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Calle 13 Featuring Caf\u00c3\u0083\u00c2\u00a9 Tacuba","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":37,"lastName":"Koch","length":293.32853,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"No Hay Nadie Como T\u00c3\u0083\u00c2\u00ba","status":200,"ts":1541157637796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Frumpies","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":134.47791,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"Fuck Kitty","status":200,"ts":1541157674796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"D-12","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":261.40689,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"Barbershop","status":200,"ts":1541157808796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Emil Gilels\/Orchestre de la Soci\u00c3\u0083\u00c2\u00a9t\u00c3\u0083\u00c2\u00a9 des Concerts du Conservatoire\/Andr\u00c3\u0083\u00c2\u00a9 Cluytens","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":375.19628,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":165,"song":"Piano Concerto No. 2 in G minor Op. 22 (2006 Digital Remaster): III. Presto","status":200,"ts":1541157850796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Dragonette","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":38,"lastName":"Koch","length":246.49098,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Fixin to Thrill","status":200,"ts":1541157930796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Pennywise","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":188.26404,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":87,"song":"The Western World","status":200,"ts":1541158064796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Kanye West","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":238.52363,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"Flashing Lights","status":200,"ts":1541158069796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Flash And The Pan","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":39,"lastName":"Koch","length":224.65261,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Waiting for a Train [Single Mix]","status":200,"ts":1541158176796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Washed Out","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":168.6722,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":165,"song":"New Theory","status":200,"ts":1541158225796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Katy Perry","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":3,"lastName":"Kirby","length":179.40853,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"I Kissed A Girl","status":200,"ts":1541158307796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"AFI","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":40,"lastName":"Koch","length":198.97424,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Miss Murder","status":200,"ts":1541158400796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Drake \/ Kanye West \/ Lil Wayne \/ Eminem","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":4,"lastName":"Kirby","length":357.66812,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"Forever","status":200,"ts":1541158486796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Crests","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":41,"lastName":"Koch","length":182.88281,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"16 Candles","status":200,"ts":1541158598796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Nirvana","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":42,"lastName":"Koch","length":219.08853,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Come As You Are","status":200,"ts":1541158780796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Knights Of The Abyss","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":5,"lastName":"Kirby","length":205.66159,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"Dragon Pie","status":200,"ts":1541158843796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Binary Star","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":43,"lastName":"Koch","length":300.19873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Honest Expression","status":200,"ts":1541158999796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Nada Surf","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":6,"lastName":"Kirby","length":181.08036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"Whose Authority","status":200,"ts":1541159048796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Blank & Jones","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":7,"lastName":"Kirby","length":310.15138,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"Beyond Time (Ambient Mix)","status":200,"ts":1541159229796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Carnifex","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":44,"lastName":"Koch","length":219.89832,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"By Darkness Enslaved","status":200,"ts":1541159299796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bono \/ Secret Machines","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":45,"lastName":"Koch","length":285.43955,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"I Am The Walrus","status":200,"ts":1541159518796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Broadcast 2000","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":8,"lastName":"Kirby","length":198.84363,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"The View","status":200,"ts":1541159539796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Pixies","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":9,"lastName":"Kirby","length":229.3024,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"Where Is My Mind?","status":200,"ts":1541159737796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":46,"lastName":"Koch","length":242.99057,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Holy Roller Novocaine","status":200,"ts":1541159803796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":10,"lastName":"Kirby","length":221.85751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"You Know I'm No Good","status":200,"ts":1541159966796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":47,"lastName":"Koch","length":252.21179,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1541160045796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Apocalyptica","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":409.86077,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":179,"song":"Coma","status":200,"ts":1541160161796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Big Tymers","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":11,"lastName":"Kirby","length":256.15628,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"Lil Mama","status":200,"ts":1541160187796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Pat Green","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":48,"lastName":"Koch","length":295.33995,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Whiskey","status":200,"ts":1541160297796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Daughtry","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":12,"lastName":"Kirby","length":249.91302,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"No Surprise","status":200,"ts":1541160443796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Air","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":212.21832,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":179,"song":"Playground Love","status":200,"ts":1541160570796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sam Cooke","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":49,"lastName":"Koch","length":122.04363,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Ain't Misbehavin","status":200,"ts":1541160592796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Live","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":13,"lastName":"Kirby","length":203.28444,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"Deep Enough","status":200,"ts":1541160692796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Everclear","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":50,"lastName":"Koch","length":222.61506,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Summerland","status":200,"ts":1541160714796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Alison Krauss \/ Union Station","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":14,"lastName":"Kirby","length":129.67138,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"Down To The River To Pray","status":200,"ts":1541160895796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":51,"lastName":"Koch","length":239.22893,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Move Along","status":200,"ts":1541160936796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Covenant","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":15,"lastName":"Kirby","length":300.19873,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":157,"song":"XRDS","status":200,"ts":1541161024796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"You Me At Six","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":191.13751,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":189,"song":"Liquid Confidence","status":200,"ts":1541161144796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Motion City Soundtrack","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":52,"lastName":"Koch","length":206.34077,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Everything Is Alright (Album Version)","status":200,"ts":1541161175796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"FM Static","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":53,"lastName":"Koch","length":169.84771,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Something To Believe In","status":200,"ts":1541161381796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Dave Gahan","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":54,"lastName":"Koch","length":272.92689,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Kingdom","status":200,"ts":1541161550796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Metallica","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":55,"lastName":"Koch","length":319.73832,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Mama Said","status":200,"ts":1541161822796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Dr. Hook","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":56,"lastName":"Koch","length":229.77261,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Sylvia's Mother","status":200,"ts":1541162141796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Gotan Project","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":57,"lastName":"Koch","length":321.30567,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Diferente","status":200,"ts":1541162370796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Carrie Underwood","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":58,"lastName":"Koch","length":221.3873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Play On","status":200,"ts":1541162691796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Ut","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":59,"lastName":"Koch","length":313.86077,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"I.D.","status":200,"ts":1541162912796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Lil Wayne \/ Eminem","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":60,"lastName":"Koch","length":229.58975,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Drop The World","status":200,"ts":1541163225796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Damage","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":61,"lastName":"Koch","length":263.18322,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"For Your Pleasure","status":200,"ts":1541163454796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Rionegro \/ Solim\u00c3\u0083\u00c2\u00b5es","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":62,"lastName":"Koch","length":280.92036,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"De S\u00c3\u0083\u00c2\u00a3o Paulo \u00c3\u0083\u00c2\u0080 Bel\u00c3\u0083\u00c2\u00a9m","status":200,"ts":1541163717796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Drive-By Truckers","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":63,"lastName":"Koch","length":246.22975,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Outfit","status":200,"ts":1541163997796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Tweet","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":64,"lastName":"Koch","length":256.39138,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Smoking Cigarettes (LP Version)","status":200,"ts":1541164243796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Ben Folds Five","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":65,"lastName":"Koch","length":207.882,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Steven's Last Night In Town","status":200,"ts":1541164499796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Glen Hansard","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":66,"lastName":"Koch","length":239.59465,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Lies","status":200,"ts":1541164706796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Chevelle","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":0,"lastName":"Barrera","length":389.85098,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":174,"song":"Dos (LP Version)","status":200,"ts":1541164749796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Bill Withers","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":67,"lastName":"Koch","length":383.73832,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Make Love To Your Mind","status":200,"ts":1541164945796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Jorge Drexler","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":1,"lastName":"Barrera","length":272.14322,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":174,"song":"Salvapantallas","status":200,"ts":1541165138796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Michael Bolton","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":68,"lastName":"Koch","length":255.65995,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"How Am I Supposed To Live Without You","status":200,"ts":1541165328796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Mercury Program","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":2,"lastName":"Barrera","length":449.12281,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":174,"song":"Marianas","status":200,"ts":1541165410796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Duran Duran","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":69,"lastName":"Koch","length":321.88036,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"The Seventh Stranger","status":200,"ts":1541165583796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Little Boots","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":70,"lastName":"Koch","length":195.94404,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Meddle","status":200,"ts":1541165904796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Johnossi","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":71,"lastName":"Koch","length":174.2624,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Glory Days To Come","status":200,"ts":1541166099796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":72,"lastName":"Koch","length":348.57751,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Undo","status":200,"ts":1541166273796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":73,"lastName":"Koch","length":226.37669,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Hey Mama","status":200,"ts":1541166621796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"DecembeRadio","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":74,"lastName":"Koch","length":249.62567,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"Find You Waiting","status":200,"ts":1541166847796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bonobo","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":75,"lastName":"Koch","length":270.41914,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":172,"song":"1009","status":200,"ts":1541167096796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":null,"level":"free","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":194,"song":null,"status":200,"ts":1541168424796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":236.09424,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":194,"song":"Canada","status":200,"ts":1541168577796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Morcheeba","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":347.71546,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":194,"song":"The Sea","status":200,"ts":1541168813796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Avett Brothers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":307.9571,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":194,"song":"All My Mistakes (US4BW0700133)","status":200,"ts":1541169160796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Dave Darell","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":217.33832,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":197,"song":"Children","status":200,"ts":1541170090796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":183,"song":null,"status":200,"ts":1541172202796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Priestess","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":190.45832,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":183,"song":"Talk To Her","status":200,"ts":1541172234796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Arcade Fire","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":169.19465,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":183,"song":"I'm Sleeping In A Submarine","status":200,"ts":1541172424796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":3,"lastName":"Smith","length":211.69587,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":183,"song":"Crescendolls","status":200,"ts":1541172593796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Nickel Creek","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":4,"lastName":"Smith","length":255.13751,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":183,"song":"When In Rome","status":200,"ts":1541172804796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Squeeze","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":5,"lastName":"Smith","length":229.56363,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":183,"song":"Footprints","status":200,"ts":1541173059796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":175.80363,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":60,"song":"Sweet Hitch-Hiker","status":200,"ts":1541173221796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Kierra Sheard","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":1,"lastName":"Gonzalez","length":299.02322,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":60,"song":"Love Like Crazy (Extended Mix)","status":200,"ts":1541173396796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":null,"auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":null,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"GET","page":"Home","registration":1540829025796.0,"sessionId":201,"song":null,"status":200,"ts":1541174197796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":null,"auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":null,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"GET","page":"Settings","registration":1540829025796.0,"sessionId":201,"song":null,"status":200,"ts":1541174308796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":null,"auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":2,"lastName":"Hess","length":null,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"Save Settings","registration":1540829025796.0,"sessionId":201,"song":null,"status":307,"ts":1541174309796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":null,"auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":3,"lastName":"Hess","length":null,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"GET","page":"Home","registration":1540829025796.0,"sessionId":201,"song":null,"status":200,"ts":1541174356796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":193,"song":null,"status":200,"ts":1541174633796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Greg Laswell","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":251.08853,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":193,"song":"Comes And Goes ( In Waves )","status":200,"ts":1541174803796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":193,"song":null,"status":200,"ts":1541174900796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Pavement","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":3,"lastName":"Rodriguez","length":99.16036,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":193,"song":"Mercy:The Laundromat","status":200,"ts":1541175054796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Sixx A.M.","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":4,"lastName":"Rodriguez","length":280.58077,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":193,"song":"Courtesy Call (Explicit)","status":200,"ts":1541175153796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Leonard Cohen","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":5,"lastName":"Rodriguez","length":267.67628,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":193,"song":"I'm Your Man","status":200,"ts":1541175433796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Tallest Man On Earth","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":0,"lastName":"Gutierrez","length":203.62404,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":167,"song":"The Wild Hunt","status":200,"ts":1541175530796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"My Chemical Romance","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":1,"lastName":"Gutierrez","length":161.90649,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":167,"song":"Teenagers (Album Version)","status":200,"ts":1541175733796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Wendy Rene","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":2,"lastName":"Gutierrez","length":182.46485,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":167,"song":"After Laughter (Comes Tears) (LP Version)","status":200,"ts":1541175894796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Jack Johnson \/ Paula Fuga","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":3,"lastName":"Gutierrez","length":178.33751,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":167,"song":"Country Road","status":200,"ts":1541176076796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":4,"lastName":"Gutierrez","length":233.69098,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":167,"song":"Invalid","status":200,"ts":1541176254796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"No Doubt","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":44.93016,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":205,"song":"BND","status":200,"ts":1541176327796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Katy Perry","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":179.40853,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":205,"song":"I Kissed A Girl","status":200,"ts":1541176371796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Neutral Milk Hotel","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":5,"lastName":"Gutierrez","length":248.37179,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":167,"song":"Ghost","status":200,"ts":1541176487796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":239.3073,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":156,"song":"You're The One","status":200,"ts":1541176500796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Ella Fitzgerald","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":6,"lastName":"Gutierrez","length":427.15383,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":167,"song":"On Green Dolphin Street (Medley) (1999 Digital Remaster)","status":200,"ts":1541176735796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Tony Rohr","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":403.09506,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":156,"song":"Van Comp","status":200,"ts":1541176739796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Braid","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":7,"lastName":"Gutierrez","length":222.74567,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":167,"song":"Divers","status":200,"ts":1541177162796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Fourmost","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":8,"lastName":"Gutierrez","length":113.6322,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":167,"song":"Hello Little Girl","status":200,"ts":1541177384796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Catupecu Machu","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":9,"lastName":"Gutierrez","length":212.32281,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":167,"song":"Hormigas","status":200,"ts":1541177497796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Creed","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":10,"lastName":"Gutierrez","length":329.87383,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":167,"song":"Weathered","status":200,"ts":1541177709796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Ennio Morricone","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":11,"lastName":"Gutierrez","length":215.01342,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":167,"song":"Chi Mai (El Profesional)","status":200,"ts":1541178038796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":null,"auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":12,"lastName":"Gutierrez","length":null,"level":"free","location":"Columbia, SC","method":"GET","page":"Upgrade","registration":1540809335796.0,"sessionId":167,"song":null,"status":200,"ts":1541178048796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Down To The Bone","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":333.76608,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":182,"song":"Keep On Keepin' On","status":200,"ts":1541178784796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Three Drives","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":1,"lastName":"Cruz","length":411.6371,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":182,"song":"Greece 2000","status":200,"ts":1541179117796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":null,"auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":0,"lastName":"Rosales","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1541059521796.0,"sessionId":11,"song":null,"status":200,"ts":1541179188796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"Sebastien Tellier","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":2,"lastName":"Cruz","length":377.73016,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":182,"song":"Kilometer","status":200,"ts":1541179528796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Lonnie Gordon","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":3,"lastName":"Cruz","length":181.21098,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":182,"song":"Catch You Baby (Steve Pitron & Max Sanna Radio Edit)","status":200,"ts":1541179905796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Charttraxx Karaoke","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":225.17506,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":207,"song":"Fireflies","status":200,"ts":1541181317796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Ska-P","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":220.21179,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":207,"song":"Ni\u00c3\u0083\u00c2\u00b1o Soldado","status":200,"ts":1541181542796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":2,"lastName":"Robinson","length":239.3073,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":207,"song":"You're The One","status":200,"ts":1541181762796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Radiohead","auth":"Logged In","firstName":"Ayleen","gender":"F","itemInSession":0,"lastName":"Wise","length":130.82077,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1541085793796.0,"sessionId":70,"song":"Pop Is Dead","status":200,"ts":1541183813796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_1 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D201 Safari\/9537.53\"","userId":"71"} {"artist":"Scouting for Girls","auth":"Logged In","firstName":"Ayleen","gender":"F","itemInSession":1,"lastName":"Wise","length":201.1424,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1541085793796.0,"sessionId":70,"song":"The Mountains Of Navaho","status":200,"ts":1541183943796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_1 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D201 Safari\/9537.53\"","userId":"71"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Ayleen","gender":"F","itemInSession":2,"lastName":"Wise","length":195.94404,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1541085793796.0,"sessionId":70,"song":"Sincerit\u00c3\u0083\u00c2\u00a9 Et Jalousie","status":200,"ts":1541184144796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_1 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D201 Safari\/9537.53\"","userId":"71"} {"artist":"OutKast","auth":"Logged In","firstName":"Ayleen","gender":"F","itemInSession":3,"lastName":"Wise","length":227.52608,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1541085793796.0,"sessionId":70,"song":"Ova Da Wudz","status":200,"ts":1541184339796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_1 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D201 Safari\/9537.53\"","userId":"71"} {"artist":"Bloodhound Gang","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":0,"lastName":"Cook","length":260.20526,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":53,"song":"Uhn Tiss Uhn Tiss Uhn Tiss","status":200,"ts":1541187675796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Rammstein","auth":"Logged In","firstName":"Isaac","gender":"M","itemInSession":0,"lastName":"Valdez","length":228.46649,"level":"free","location":"Saginaw, MI","method":"PUT","page":"NextSong","registration":1541078099796.0,"sessionId":112,"song":"Adios","status":200,"ts":1541191023796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"3"} {"artist":"Gershon Kingsley","auth":"Logged In","firstName":"Isaac","gender":"M","itemInSession":1,"lastName":"Valdez","length":146.57261,"level":"free","location":"Saginaw, MI","method":"PUT","page":"NextSong","registration":1541078099796.0,"sessionId":112,"song":"Pop Corn","status":200,"ts":1541191251796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"3"} {"artist":"The Rakes","auth":"Logged In","firstName":"Isaac","gender":"M","itemInSession":2,"lastName":"Valdez","length":150.59546,"level":"free","location":"Saginaw, MI","method":"PUT","page":"NextSong","registration":1541078099796.0,"sessionId":112,"song":"Strasbourg","status":200,"ts":1541191397796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"3"}
487.807018
684
0.699109
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":52,"song":null,"status":307,"ts":1541207073796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":1,"lastName":"Williams","length":null,"level":"free","location":"Klamath Falls, OR","method":"GET","page":"Home","registration":1541077528796.0,"sessionId":52,"song":null,"status":200,"ts":1541207123796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Mynt","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":2,"lastName":"Williams","length":166.94812,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":52,"song":"Playa Haters","status":200,"ts":1541207150796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":3,"lastName":"Williams","length":230.47791,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":52,"song":"You Belong With Me","status":200,"ts":1541207316796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":4,"lastName":"Williams","length":229.85098,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":52,"song":"Valerie","status":200,"ts":1541207546796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Jimmy Eat World","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":5,"lastName":"Williams","length":285.83138,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":52,"song":"Dizzy","status":200,"ts":1541207775796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":18,"song":null,"status":200,"ts":1541239749796,"userAgent":null,"userId":""} {"artist":"Maldita Nerea","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":241.162,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":158,"song":"Supelicula","status":200,"ts":1541254670796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Fluke","auth":"Logged In","firstName":"Connar","gender":"M","itemInSession":0,"lastName":"Moreno","length":478.92853,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540823606796.0,"sessionId":168,"song":"Bermuda","status":200,"ts":1541257880796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10) AppleWebKit\/538.46 (KHTML, like Gecko) Version\/8.0 Safari\/538.46\"","userId":"62"} {"artist":"Habib Koit\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":285.1522,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":185,"song":"Din Din Wo","status":200,"ts":1541259368796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"The Kooks","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":0,"lastName":"Johnson","length":132.25751,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Eddie's Gun","status":200,"ts":1541260356796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Blues Traveler","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":1,"lastName":"Johnson","length":290.24608,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Hook","status":200,"ts":1541260488796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Coldplay","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":2,"lastName":"Johnson","length":298.762,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Shiver","status":200,"ts":1541260778796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Tom Petty And The Heartbreakers","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":3,"lastName":"Johnson","length":183.01342,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"The Wild One_ Forever","status":200,"ts":1541261076796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Girl Talk","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":4,"lastName":"Johnson","length":173.24363,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Give and Go","status":200,"ts":1541261259796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":5,"lastName":"Johnson","length":258.55955,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Cosmic Love","status":200,"ts":1541261432796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Three Drives","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":6,"lastName":"Johnson","length":411.6371,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Greece 2000","status":200,"ts":1541261690796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Jonas Brothers","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":7,"lastName":"Johnson","length":192.36526,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Sorry","status":200,"ts":1541262101796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Tevin Campbell","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":8,"lastName":"Johnson","length":293.04118,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Round And Round (Soul Mix Edit)","status":200,"ts":1541262293796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Sting","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":9,"lastName":"Johnson","length":257.12281,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Windmills Of Your Mind","status":200,"ts":1541262586796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Champs","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":10,"lastName":"Johnson","length":132.0224,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Tequila","status":200,"ts":1541262843796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"R\u00c3\u0083\u00c2\u00b6yksopp","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":11,"lastName":"Johnson","length":214.93506,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Poor Leno Jakatta Radio Mix","status":200,"ts":1541262975796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Avenged Sevenfold","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":12,"lastName":"Johnson","length":312.11057,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Bat Country (Album Version)","status":200,"ts":1541263189796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Home","registration":1540266185796.0,"sessionId":210,"song":null,"status":200,"ts":1541263390796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Sam Cooke","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":13,"lastName":"Johnson","length":122.04363,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Ain't Misbehavin","status":200,"ts":1541263501796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Apulanta","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":14,"lastName":"Johnson","length":219.53261,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Hallaa","status":200,"ts":1541263623796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Era","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":15,"lastName":"Johnson","length":200.56771,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Cathar Rhythm","status":200,"ts":1541263842796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Klaus Badelt","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":1,"lastName":"Cruz","length":128.62649,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":210,"song":"Moonlight Serenade","status":200,"ts":1541264015796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Parov Stelar","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":16,"lastName":"Johnson","length":281.5473,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"KissKiss","status":200,"ts":1541264042796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Koch","length":290.48118,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Rabbit Heart (Raise It Up)","status":200,"ts":1541264282796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"De La Soul","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":17,"lastName":"Johnson","length":221.72689,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Me_ Myself & I","status":200,"ts":1541264323796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Lil Wayne \/ T-Pain","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":18,"lastName":"Johnson","length":244.58404,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Got Money","status":200,"ts":1541264544796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Cher","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Koch","length":167.41832,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Milord","status":200,"ts":1541264572796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Edge Of Dawn","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Koch","length":253.72689,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Losing Ground","status":200,"ts":1541264739796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":19,"lastName":"Johnson","length":223.84281,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Elevator","status":200,"ts":1541264788796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Smokie Norful","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Koch","length":337.84118,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"I Need You Now (Build A Bridge Version)","status":200,"ts":1541264992796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Adam Lambert","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":20,"lastName":"Johnson","length":227.39546,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Whataya Want From Me","status":200,"ts":1541265011796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Pulp","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":21,"lastName":"Johnson","length":208.95302,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Little Girl (With Blue Eyes)","status":200,"ts":1541265238796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Koch","length":265.76934,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Creil City","status":200,"ts":1541265329796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Tricky","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":22,"lastName":"Johnson","length":212.79302,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Ponderosa","status":200,"ts":1541265446796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"John Butler Trio","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":5,"lastName":"Koch","length":223.68608,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Betterman (full-length\/album version)","status":200,"ts":1541265594796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Culture Club","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":23,"lastName":"Johnson","length":282.48771,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Believe (Demo)","status":200,"ts":1541265658796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Temper Trap","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":6,"lastName":"Koch","length":192.67873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Fader","status":200,"ts":1541265817796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"La Mosca Tse-Tse","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":24,"lastName":"Johnson","length":195.082,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Patadas En El Corazon","status":200,"ts":1541265940796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Cute Is What We Aim For","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":7,"lastName":"Koch","length":201.22077,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Finger Twist & Split (Album Version)","status":200,"ts":1541266009796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":25,"lastName":"Johnson","length":236.72118,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Bubble Toes","status":200,"ts":1541266135796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Siriusmo","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":8,"lastName":"Koch","length":272.61342,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Simple","status":200,"ts":1541266210796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":26,"lastName":"Johnson","length":312.89424,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Feelin' Blue","status":200,"ts":1541266371796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Alberto Plaza","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":9,"lastName":"Koch","length":271.3073,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"No Seas Cruel (vivo)","status":200,"ts":1541266482796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Brand New","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":27,"lastName":"Johnson","length":188.49914,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Not The Sun","status":200,"ts":1541266683796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Sean Lennon","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":10,"lastName":"Koch","length":202.97098,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Into The Sun","status":200,"ts":1541266753796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"K-OS","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":28,"lastName":"Johnson","length":211.33016,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"EMCEE Murdah","status":200,"ts":1541266871796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Nana Caymmi","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":11,"lastName":"Koch","length":251.0624,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Acercate Mas (2000 Digital Remaster)","status":200,"ts":1541266955796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Casino Versus Japan","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":29,"lastName":"Johnson","length":86.30812,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Moonlupe","status":200,"ts":1541267082796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"the bird and the bee","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":30,"lastName":"Johnson","length":281.23383,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Ray Gun","status":200,"ts":1541267168796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Skyforger","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":12,"lastName":"Koch","length":38.94812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"In the Yard of the Father's Son","status":200,"ts":1541267206796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bryan Ferry","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":13,"lastName":"Koch","length":265.87383,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Slave To Love (1999 Digital Remaster)","status":200,"ts":1541267244796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":31,"lastName":"Johnson","length":196.91057,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"All Hands Against His Own","status":200,"ts":1541267449796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Foxy Shazam","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":14,"lastName":"Koch","length":201.74322,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Wanna-be Angel (Album Version)","status":200,"ts":1541267509796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Ruts","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":32,"lastName":"Johnson","length":338.96444,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"West One (Shine On Me)","status":200,"ts":1541267645796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Old 97's","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":15,"lastName":"Koch","length":231.28771,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Victoria (LP Version)","status":200,"ts":1541267710796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Lonnie Gordon","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":16,"lastName":"Koch","length":181.21098,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Catch You Baby (Steve Pitron & Max Sanna Radio Edit)","status":200,"ts":1541267941796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bon Iver","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":33,"lastName":"Johnson","length":220.70812,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"For Emma","status":200,"ts":1541267983796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":17,"lastName":"Koch","length":219.66322,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1541268122796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Glen Washington","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":34,"lastName":"Johnson","length":193.82812,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"One Of These Days","status":200,"ts":1541268203796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Mad Cobra","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":18,"lastName":"Koch","length":230.68689,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Flex","status":200,"ts":1541268341796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Dropout Year","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":35,"lastName":"Johnson","length":227.36934,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"This Notebook","status":200,"ts":1541268396796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Flogging Molly","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":19,"lastName":"Koch","length":260.75383,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Punch Drunk Grinning Soul","status":200,"ts":1541268571796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Young Rebel Set","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":36,"lastName":"Johnson","length":248.55465,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"If I Was","status":200,"ts":1541268623796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Sneaker Pimps","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":20,"lastName":"Koch","length":260.91057,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Spin Spin Sugar","status":200,"ts":1541268831796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Righteous Brothers","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":37,"lastName":"Johnson","length":215.90159,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Unchained Melody","status":200,"ts":1541268871796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Me First And The Gimme Gimmes","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":38,"lastName":"Johnson","length":64.39138,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Jonny's Blessing","status":200,"ts":1541269086796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Texas In July","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":21,"lastName":"Koch","length":190.69342,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Aurora","status":200,"ts":1541269091796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Alice In Chains","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":39,"lastName":"Johnson","length":230.60853,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"God Smack","status":200,"ts":1541269150796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":40,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Downgrade","registration":1540809153796.0,"sessionId":152,"song":null,"status":200,"ts":1541269220796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"10 Years","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":22,"lastName":"Koch","length":229.95546,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Wasteland","status":200,"ts":1541269281796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Juanes","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":23,"lastName":"Koch","length":233.40363,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"No Siento Penas","status":200,"ts":1541269510796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":41,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Downgrade","registration":1540809153796.0,"sessionId":152,"song":null,"status":200,"ts":1541269515796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":42,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Home","registration":1540809153796.0,"sessionId":152,"song":null,"status":200,"ts":1541269560796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":43,"lastName":"Johnson","length":200.202,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Wild World","status":200,"ts":1541269636796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Passion Pit","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":24,"lastName":"Koch","length":174.75873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Sleepyhead","status":200,"ts":1541269743796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Temper Trap","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":44,"lastName":"Johnson","length":192.67873,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Fader","status":200,"ts":1541269836796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":25,"lastName":"Koch","length":224.67873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Secrets","status":200,"ts":1541269917796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Diplo","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":45,"lastName":"Johnson","length":96.86159,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Florida","status":200,"ts":1541270028796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Afro Celt Sound System","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":46,"lastName":"Johnson","length":425.01179,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Even In My Dreams","status":200,"ts":1541270124796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"PeterLicht","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":26,"lastName":"Koch","length":306.80771,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":199,"song":"Heiterkeit","status":200,"ts":1541270141796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":27,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Downgrade","registration":1541048010796.0,"sessionId":199,"song":null,"status":200,"ts":1541270199796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"M.A. Numminen","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":47,"lastName":"Johnson","length":166.55628,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"TULENLIEKKI","status":200,"ts":1541270549796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":48,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Home","registration":1540809153796.0,"sessionId":152,"song":null,"status":200,"ts":1541270836796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Limp Bizkit","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":49,"lastName":"Johnson","length":214.5171,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Rollin' (Air Raid Vehicle)","status":200,"ts":1541270854796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Downhere","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":50,"lastName":"Johnson","length":230.71302,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"In America (Album Version)","status":200,"ts":1541271068796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Roots Manuva","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":51,"lastName":"Johnson","length":233.92608,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"No Love","status":200,"ts":1541271298796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Lykke Li","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":52,"lastName":"Johnson","length":162.19383,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Let It Fall","status":200,"ts":1541271531796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Plan B","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":53,"lastName":"Johnson","length":222.82404,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Free","status":200,"ts":1541271693796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Octopus Project","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":54,"lastName":"Johnson","length":498.33751,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Hypnopaedia","status":200,"ts":1541271915796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":55,"lastName":"Johnson","length":224.67873,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Secrets","status":200,"ts":1541272413796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Gilberto Santa Rosa","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":56,"lastName":"Johnson","length":272.16934,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"La Sigo Amando Tanto","status":200,"ts":1541272637796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Eric Clapton","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":57,"lastName":"Johnson","length":271.80363,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Tears In Heaven","status":200,"ts":1541272909796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"ARRESTED DEVELOPMENT","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":58,"lastName":"Johnson","length":200.98567,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Fountain Of Youth","status":200,"ts":1541273180796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":59,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Home","registration":1540809153796.0,"sessionId":152,"song":null,"status":200,"ts":1541273268796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Future Rock","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":60,"lastName":"Johnson","length":239.90812,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Gears","status":200,"ts":1541273380796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Steppenwolf","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":61,"lastName":"Johnson","length":208.14322,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Born To Be Wild","status":200,"ts":1541273619796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Jason Mraz & Colbie Caillat","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":62,"lastName":"Johnson","length":189.6224,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"Lucky (Album Version)","status":200,"ts":1541273827796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Leonard Cohen","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":63,"lastName":"Johnson","length":298.57914,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":152,"song":"The Stranger Song","status":200,"ts":1541274016796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Bright Eyes","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":279.09179,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":135,"song":"Kathy with a K's Song","status":200,"ts":1541277256796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":195,"song":null,"status":200,"ts":1541279200796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Smiths","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":196.67546,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":195,"song":"The Boy With The Thorn In His Side","status":200,"ts":1541279668796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Quique Gonzalez","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":214.20363,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":195,"song":"Cuando Eramos Reyes","status":200,"ts":1541279864796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Muse","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":210.46812,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":195,"song":"Pink Ego Box","status":200,"ts":1541280078796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sugarland","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":247.77098,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":5,"song":"Just Might (Make Me Believe)","status":200,"ts":1541287022796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"A Hope For Home","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":1,"lastName":"Owens","length":388.38812,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":5,"song":"Absolution: Of Flight and Failure","status":200,"ts":1541287269796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"}
486.252252
543
0.697101
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540306145796.0,"sessionId":154,"song":null,"status":200,"ts":1541290555796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Professor Longhair","auth":"Logged In","firstName":"Ann","gender":"F","itemInSession":0,"lastName":"Banks","length":214.20363,"level":"free","location":"Salt Lake City, UT","method":"PUT","page":"NextSong","registration":1540895683796.0,"sessionId":124,"song":"Mean Ol'World","status":200,"ts":1541292603796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"99"} {"artist":null,"auth":"Logged In","firstName":"Jahiem","gender":"M","itemInSession":0,"lastName":"Miles","length":null,"level":"free","location":"San Antonio-New Braunfels, TX","method":"GET","page":"Home","registration":1540817347796.0,"sessionId":42,"song":null,"status":200,"ts":1541299033796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"43"} {"artist":"Gary Hobbs","auth":"Logged In","firstName":"Jahiem","gender":"M","itemInSession":1,"lastName":"Miles","length":245.52444,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540817347796.0,"sessionId":42,"song":"En Mi Mundo","status":200,"ts":1541300092796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"43"} {"artist":"Lifehouse","auth":"Logged In","firstName":"Jahiem","gender":"M","itemInSession":2,"lastName":"Miles","length":203.59791,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540817347796.0,"sessionId":42,"song":"We'll Never Know","status":200,"ts":1541300337796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"43"} {"artist":"Olivia Ruiz","auth":"Logged In","firstName":"Jahiem","gender":"M","itemInSession":3,"lastName":"Miles","length":254.74567,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540817347796.0,"sessionId":42,"song":"Cabaret Blanco","status":200,"ts":1541300540796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"43"} {"artist":null,"auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":null,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1541032432796.0,"sessionId":225,"song":null,"status":200,"ts":1541304686796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Jordan Rudess","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":1,"lastName":"Owens","length":1367.84934,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":225,"song":"Tarkus","status":200,"ts":1541306152796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Deerhunter","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Graves","length":162.08934,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Weird Era","status":200,"ts":1541310546796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Daughtry","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Graves","length":249.91302,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"No Surprise","status":200,"ts":1541310708796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"Logout","registration":1540664184796.0,"sessionId":128,"song":null,"status":307,"ts":1541310709796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":128,"song":null,"status":200,"ts":1541310732796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":128,"song":null,"status":307,"ts":1541310733796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":5,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Home","registration":1540664184796.0,"sessionId":128,"song":null,"status":200,"ts":1541310741796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Vinylshakerz","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":6,"lastName":"Graves","length":207.25506,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Club Tropicana","status":200,"ts":1541310957796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":7,"lastName":"Graves","length":277.15873,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1541311164796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Son House","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":8,"lastName":"Graves","length":182.43873,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Depot Blues","status":200,"ts":1541311441796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Jason Mraz & Colbie Caillat","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":9,"lastName":"Graves","length":189.6224,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Lucky (Album Version)","status":200,"ts":1541311623796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The Romantics","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":10,"lastName":"Graves","length":233.7171,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Talking In Your Sleep","status":200,"ts":1541311812796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The Postal Service","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":11,"lastName":"Graves","length":266.47465,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Such Great Heights","status":200,"ts":1541312045796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Tweet","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":12,"lastName":"Graves","length":281.80853,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Always Will (LP Version)","status":200,"ts":1541312311796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Gang Starr\/Inspectah Deck","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":13,"lastName":"Graves","length":225.07057,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Above The Clouds (Edited)","status":200,"ts":1541312592796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Kanye West","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":14,"lastName":"Graves","length":164.38812,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Coldest Winter","status":200,"ts":1541312817796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Shunza","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":15,"lastName":"Graves","length":250.93179,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Nan Ni Wan","status":200,"ts":1541312981796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Erykah Badu","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":16,"lastName":"Graves","length":286.9024,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Back In The Day","status":200,"ts":1541313231796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":17,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Home","registration":1540664184796.0,"sessionId":128,"song":null,"status":200,"ts":1541313291796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":18,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Settings","registration":1540664184796.0,"sessionId":128,"song":null,"status":200,"ts":1541313291796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Mariza","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":0,"lastName":"Burke","length":239.3073,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":143,"song":"Vielas De Alfama","status":200,"ts":1541313299796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":19,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Settings","registration":1540664184796.0,"sessionId":128,"song":null,"status":200,"ts":1541313325796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":20,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"Save Settings","registration":1540664184796.0,"sessionId":128,"song":null,"status":307,"ts":1541313326796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":21,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Home","registration":1540664184796.0,"sessionId":128,"song":null,"status":200,"ts":1541313397796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Asia 2001","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":22,"lastName":"Graves","length":150.30812,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Epilogue","status":200,"ts":1541313517796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Alejandro Sanz","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":1,"lastName":"Burke","length":230.24281,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":143,"song":"Non E_ Per Te_ Per Me","status":200,"ts":1541313538796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"The Casualties","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":23,"lastName":"Graves","length":131.23873,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Fight For Your Life","status":200,"ts":1541313667796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":24,"lastName":"Graves","length":252.21179,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1541313798796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Hey Monday","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":25,"lastName":"Graves","length":222.98077,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Run_ Don't Walk","status":200,"ts":1541314050796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Silverchair","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":26,"lastName":"Graves","length":213.13261,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"The Door","status":200,"ts":1541314272796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"El DeBarge","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":27,"lastName":"Graves","length":323.47383,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Love Always","status":200,"ts":1541314485796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Evanescence","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":28,"lastName":"Graves","length":236.12036,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Bring Me To Life","status":200,"ts":1541314808796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":29,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Help","registration":1540664184796.0,"sessionId":128,"song":null,"status":200,"ts":1541314903796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Ludovico Einaudi","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":30,"lastName":"Graves","length":249.02485,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"The Snow Prelude No. 2","status":200,"ts":1541315044796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Caifanes","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":31,"lastName":"Graves","length":210.88608,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Ayer Me Dijo Un Ave","status":200,"ts":1541315293796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The xx","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":32,"lastName":"Graves","length":188.55138,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Basic Space","status":200,"ts":1541315503796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Swizz Beatz","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":33,"lastName":"Graves","length":213.7073,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Big Munny","status":200,"ts":1541315691796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"OutKast","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":34,"lastName":"Graves","length":239.35955,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Ms. Jackson","status":200,"ts":1541315904796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":35,"lastName":"Graves","length":300.30322,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"The Only One","status":200,"ts":1541316143796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Nappy Roots [featuring Anthony Hamilton]","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":36,"lastName":"Graves","length":248.00608,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Po' Folks","status":200,"ts":1541316443796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Whitesnake","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":37,"lastName":"Graves","length":250.3571,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Fool For Your Loving","status":200,"ts":1541316691796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Foolish Things","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":38,"lastName":"Graves","length":266.86649,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Who Can Compare","status":200,"ts":1541316941796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Soda Stereo","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":39,"lastName":"Graves","length":317.6224,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Pr\u00c3\u0083\u00c2\u00b3fugos","status":200,"ts":1541317207796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Edward Sharpe & The Magnetic Zeros","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":40,"lastName":"Graves","length":306.31138,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":128,"song":"Home","status":200,"ts":1541317524796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":202,"song":null,"status":200,"ts":1541318378796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Anberlin","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":258.42893,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Dismantle. Repair.","status":200,"ts":1541323143796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Help","registration":1541022995796.0,"sessionId":196,"song":null,"status":200,"ts":1541323169796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"L-7","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":168.56771,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Shitlist","status":200,"ts":1541323401796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":3,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":196,"song":null,"status":200,"ts":1541323418796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Future Of The Left","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":4,"lastName":"Kirby","length":112.63955,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Fingers Become Thumbs","status":200,"ts":1541323569796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Franz Ferdinand","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":5,"lastName":"Kirby","length":206.28853,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Call Me","status":200,"ts":1541323681796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Travie McCoy","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":6,"lastName":"Kirby","length":211.12118,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Billionaire [feat. Bruno Mars] (Explicit Album Version)","status":200,"ts":1541323887796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":7,"lastName":"Kirby","length":194.76853,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Smile","status":200,"ts":1541324098796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Rancid","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":8,"lastName":"Kirby","length":223.65995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Fall Back Down (Album Version)","status":200,"ts":1541324292796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Katy Perry","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":9,"lastName":"Kirby","length":228.49261,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"I'm Still Breathing","status":200,"ts":1541324515796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Freestylers","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":10,"lastName":"Kirby","length":340.06159,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Punks (Krafty Kuts Remix)","status":200,"ts":1541324743796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":0,"lastName":"George","length":null,"level":"free","location":"Birmingham-Hoover, AL","method":"GET","page":"Home","registration":1541020249796.0,"sessionId":15,"song":null,"status":200,"ts":1541324956796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Kid Rock","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":1,"lastName":"George","length":296.95955,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":15,"song":"All Summer Long (Album Version)","status":200,"ts":1541325032796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"LITE","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":11,"lastName":"Kirby","length":248.08444,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"On A Gloomy Evening","status":200,"ts":1541325083796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Killers","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":2,"lastName":"George","length":220.89098,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":15,"song":"When You Were Young","status":200,"ts":1541325328796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Hymie's Basement","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":12,"lastName":"Kirby","length":175.38567,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Ghost Dream","status":200,"ts":1541325331796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Pavement","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":13,"lastName":"Kirby","length":195.73506,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Rooftop Gambler","status":200,"ts":1541325506796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Trey Songz","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":3,"lastName":"George","length":205.81832,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":15,"song":"Can't Help But Wait (Album Version)","status":200,"ts":1541325548796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Shakira","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":14,"lastName":"Kirby","length":159.05914,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"La Pared","status":200,"ts":1541325701796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Billy J Kramer & The Dakotas","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":4,"lastName":"George","length":191.32036,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":15,"song":"Tennessee Waltz (Live)","status":200,"ts":1541325753796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":15,"lastName":"Kirby","length":138.10893,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"D is for Dangerous","status":200,"ts":1541325860796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":16,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Settings","registration":1541022995796.0,"sessionId":196,"song":null,"status":200,"ts":1541325893796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":17,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":196,"song":null,"status":200,"ts":1541325928796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Dashboard Confessional","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":5,"lastName":"George","length":224.54812,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":15,"song":"Ghost Of A Good Thing","status":200,"ts":1541325944796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":6,"lastName":"George","length":null,"level":"free","location":"Birmingham-Hoover, AL","method":"GET","page":"Home","registration":1541020249796.0,"sessionId":15,"song":null,"status":200,"ts":1541325951796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Moby","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":18,"lastName":"Kirby","length":196.75383,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Lift Me Up","status":200,"ts":1541325998796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Dan Deacon","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":19,"lastName":"Kirby","length":483.89179,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Snookered","status":200,"ts":1541326194796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Puddle Of Mudd","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":20,"lastName":"Kirby","length":210.80771,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Psycho","status":200,"ts":1541326677796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Red Hot Chili Peppers","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":21,"lastName":"Kirby","length":334.65424,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Snow [Hey Oh] (Album Version)","status":200,"ts":1541326887796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Barbarians","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":22,"lastName":"Kirby","length":149.44608,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Memphis_ Tennessee","status":200,"ts":1541327221796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Julia Fordham","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":23,"lastName":"Kirby","length":213.44608,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Jump (Live)","status":200,"ts":1541327370796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Alicia Keys","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":24,"lastName":"Kirby","length":455.52281,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Streets Of New York (City Life)","status":200,"ts":1541327583796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Regina Spektor","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":25,"lastName":"Kirby","length":247.69261,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Another Town","status":200,"ts":1541328038796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Deborah Harry & Iggy Pop","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":26,"lastName":"Kirby","length":207.49016,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Well Did You Evah!","status":200,"ts":1541328285796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Dr. Dre \/ Eminem \/ Alvin Joiner","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":27,"lastName":"Kirby","length":244.21832,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"What's The Difference","status":200,"ts":1541328492796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Marcel Woods","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":28,"lastName":"Kirby","length":424.33261,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Advanced (Ton T.B. Mix)","status":200,"ts":1541328736796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":29,"lastName":"Kirby","length":208.14322,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Apologize","status":200,"ts":1541329160796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":30,"lastName":"Kirby","length":172.22485,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"The Maestro","status":200,"ts":1541329368796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":175,"song":null,"status":200,"ts":1541329386796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Home","registration":1541044398796.0,"sessionId":217,"song":null,"status":200,"ts":1541329492796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Paramore","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":31,"lastName":"Kirby","length":267.65016,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"The Only Exception (Album Version)","status":200,"ts":1541329540796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Varios","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":32,"lastName":"Kirby","length":204.64281,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Hasta siempre","status":200,"ts":1541329807796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":33,"lastName":"Kirby","length":191.76444,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Howlin\u0019 For You","status":200,"ts":1541330011796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Muse","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":34,"lastName":"Kirby","length":198.79138,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Feeling Good","status":200,"ts":1541330202796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Frankie J","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":35,"lastName":"Kirby","length":254.32771,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Daddy's Little Girl","status":200,"ts":1541330400796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kirk Franklin & The Family","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":36,"lastName":"Kirby","length":418.71628,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Now Behold The Lamb","status":200,"ts":1541330654796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Cooly's Hot Box","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":37,"lastName":"Kirby","length":371.06893,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Make Me Happy","status":200,"ts":1541331072796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Ron Van Den Beuken","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":506.5922,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":229,"song":"Timeless","status":200,"ts":1541331102796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Sparks","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":38,"lastName":"Kirby","length":199.02649,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Lost And Found","status":200,"ts":1541331443796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Regina Spektor","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":39,"lastName":"Kirby","length":191.08526,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"The Calculation (Album Version)","status":200,"ts":1541331642796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Subhumans","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":40,"lastName":"Kirby","length":209.37098,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Rain","status":200,"ts":1541331833796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":41,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Help","registration":1541022995796.0,"sessionId":196,"song":null,"status":200,"ts":1541331860796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":42,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":196,"song":null,"status":200,"ts":1541331925796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Sia","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":43,"lastName":"Kirby","length":302.602,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Beautiful Calm Driving","status":200,"ts":1541332042796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Shadows Fall","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":44,"lastName":"Kirby","length":178.65098,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Lead Me Home","status":200,"ts":1541332344796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Eminem \/ Dr. Dre \/ 50 Cent","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":45,"lastName":"Kirby","length":297.56036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Crack A Bottle","status":200,"ts":1541332522796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Vampire Weekend","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":46,"lastName":"Kirby","length":195.7873,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":196,"song":"Oxford Comma (Album)","status":200,"ts":1541332819796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":null,"level":"free","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":200,"song":null,"status":200,"ts":1541337092796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":null,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"Logout","registration":1540794356796.0,"sessionId":200,"song":null,"status":307,"ts":1541337093796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":200,"song":null,"status":200,"ts":1541337277796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":31,"song":null,"status":200,"ts":1541338539796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Eddie Floyd","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":198.19057,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":31,"song":"Guess Who","status":200,"ts":1541338610796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"The Swell Season","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":319.13751,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":220,"song":"If You Want Me (Live)","status":200,"ts":1541338826796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Alex Band","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":238.8371,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":145,"song":"Tonight (Single Mix)","status":200,"ts":1541339036796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Nightwish","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":1,"lastName":"Cruz","length":305.97179,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":220,"song":"The Islander","status":200,"ts":1541339145796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Cartola","auth":"Logged In","firstName":"Brantley","gender":"M","itemInSession":0,"lastName":"West","length":172.12036,"level":"free","location":"Portland-Vancouver-Hillsboro, OR-WA","method":"PUT","page":"NextSong","registration":1541056614796.0,"sessionId":133,"song":"As Rosas N\u00c3\u0083\u00c2\u00a3o Falam","status":200,"ts":1541339696796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"28"} {"artist":"Vampire Weekend","auth":"Logged In","firstName":"Brantley","gender":"M","itemInSession":1,"lastName":"West","length":269.16526,"level":"free","location":"Portland-Vancouver-Hillsboro, OR-WA","method":"PUT","page":"NextSong","registration":1541056614796.0,"sessionId":133,"song":"I Think Ur A Contra","status":200,"ts":1541339868796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"28"} {"artist":"Sebadoh","auth":"Logged In","firstName":"Brantley","gender":"M","itemInSession":2,"lastName":"West","length":210.18077,"level":"free","location":"Portland-Vancouver-Hillsboro, OR-WA","method":"PUT","page":"NextSong","registration":1541056614796.0,"sessionId":133,"song":"Hassle","status":200,"ts":1541340137796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"28"} {"artist":"Incubus","auth":"Logged In","firstName":"Brantley","gender":"M","itemInSession":3,"lastName":"West","length":212.74077,"level":"free","location":"Portland-Vancouver-Hillsboro, OR-WA","method":"PUT","page":"NextSong","registration":1541056614796.0,"sessionId":133,"song":"Wish You Were Here","status":200,"ts":1541340347796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"28"} {"artist":"Blue States","auth":"Logged In","firstName":"Brantley","gender":"M","itemInSession":4,"lastName":"West","length":239.3073,"level":"free","location":"Portland-Vancouver-Hillsboro, OR-WA","method":"PUT","page":"NextSong","registration":1541056614796.0,"sessionId":133,"song":"Allies","status":200,"ts":1541340559796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"28"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":238,"song":null,"status":200,"ts":1541341786796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":238,"song":null,"status":307,"ts":1541341787796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":null,"level":"free","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":238,"song":null,"status":200,"ts":1541343019796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Magdalene","gender":"F","itemInSession":0,"lastName":"Herman","length":null,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"GET","page":"Home","registration":1540766630796.0,"sessionId":141,"song":null,"status":200,"ts":1541343757796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"77"} {"artist":"Octopus Project","auth":"Logged In","firstName":"Magdalene","gender":"F","itemInSession":1,"lastName":"Herman","length":498.33751,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540766630796.0,"sessionId":141,"song":"Hypnopaedia","status":200,"ts":1541343771796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"77"} {"artist":"Mike Posner","auth":"Logged In","firstName":"Jahiem","gender":"M","itemInSession":0,"lastName":"Miles","length":214.7522,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540817347796.0,"sessionId":228,"song":"Cooler Than Me","status":200,"ts":1541344071796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"43"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Roth","length":252.21179,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":176,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1541345129796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Roth","length":null,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"GET","page":"Home","registration":1540699429796.0,"sessionId":176,"song":null,"status":200,"ts":1541345129796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Roth","length":null,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"GET","page":"Home","registration":1540699429796.0,"sessionId":176,"song":null,"status":200,"ts":1541345142796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":null,"auth":"Logged In","firstName":"Braden","gender":"M","itemInSession":0,"lastName":"Parker","length":null,"level":"free","location":"Youngstown-Warren-Boardman, OH-PA","method":"GET","page":"Home","registration":1540999292796.0,"sessionId":164,"song":null,"status":200,"ts":1541345211796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"74"} {"artist":"Gang Starr\/Inspectah Deck","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Roth","length":225.07057,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":176,"song":"Above The Clouds (Edited)","status":200,"ts":1541345381796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":"Was (Not Was)","auth":"Logged In","firstName":"Braden","gender":"M","itemInSession":1,"lastName":"Parker","length":239.15057,"level":"free","location":"Youngstown-Warren-Boardman, OH-PA","method":"PUT","page":"NextSong","registration":1540999292796.0,"sessionId":164,"song":"Shake Your Head","status":200,"ts":1541345543796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"74"} {"artist":"23 Skidoo","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Roth","length":370.88608,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":176,"song":"Crossfire","status":200,"ts":1541345606796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Roth","length":239.3073,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":176,"song":"You're The One","status":200,"ts":1541345976796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":null,"auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":0,"lastName":"Barrera","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540835983796.0,"sessionId":198,"song":null,"status":200,"ts":1541347731796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Finger Eleven","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":1,"lastName":"Barrera","length":259.68281,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":198,"song":"Obvious Heart","status":200,"ts":1541348328796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Shaggy","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":2,"lastName":"Barrera","length":212.97587,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":198,"song":"Intoxication","status":200,"ts":1541348587796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Kid Cudi","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":227.34322,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":235,"song":"Up Up & Away","status":200,"ts":1541348754796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Klaus Doldinger's Passport","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":3,"lastName":"Barrera","length":460.43383,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":198,"song":"Fairy Tale","status":200,"ts":1541348799796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Aesop Rock","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":1,"lastName":"Simpson","length":245.65506,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":235,"song":"None Shall Pass (Main)","status":200,"ts":1541348981796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":null,"auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":0,"lastName":"Johnson","length":null,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"GET","page":"Home","registration":1541081807796.0,"sessionId":54,"song":null,"status":200,"ts":1541350228796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"Salt 'n' Pepa with En Vogue","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":0,"lastName":"Harris","length":296.202,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":134,"song":"Whatta Man (Salt-N-Pepa Featuring En Vogue) (EP Version)","status":200,"ts":1541351496796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Tiger Army","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":1,"lastName":"Harris","length":129.38404,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":134,"song":"Ghost Tigers Rise (Album Version)","status":200,"ts":1541351792796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"NEEDTOBREATHE","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":2,"lastName":"Harris","length":225.82812,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":134,"song":"Don't Wait For Daylight (Album Version)","status":200,"ts":1541351921796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":null,"auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540492941796.0,"sessionId":203,"song":null,"status":200,"ts":1541353043796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":234,"song":null,"status":200,"ts":1541354594796,"userAgent":null,"userId":""} {"artist":"Baby Huey & The Baby Sitters","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":194.7424,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":243,"song":"Hard Times (LP Version)","status":200,"ts":1541356206796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":220.89098,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":243,"song":"Somebody To Love","status":200,"ts":1541356400796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"David Byrne & Fatboy Slim feat. Charmaine Clamor","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":238.65424,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":243,"song":"Walk Like A Woman (Album Version)","status":200,"ts":1541356620796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":230.47791,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":243,"song":"You Belong With Me","status":200,"ts":1541356858796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Ottmar Liebert","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":174.54975,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":243,"song":"Festival (Of 7 Lights)","status":200,"ts":1541357088796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Roots","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":0,"lastName":"Klein","length":285.6224,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Dynamite!","status":200,"ts":1541358875796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":1,"lastName":"Klein","length":235.28444,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Learn To Fly","status":200,"ts":1541359160796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"El Hombre Burbuja","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":2,"lastName":"Klein","length":161.33179,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Buzos (En La Luna)","status":200,"ts":1541359395796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Rock Kills Kid","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":3,"lastName":"Klein","length":271.38567,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Back To Life (Album Version)","status":200,"ts":1541359556796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Manu Chao","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":4,"lastName":"Klein","length":288.15628,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Me Quedo Contigo [Si Me Das A Elegir]","status":200,"ts":1541359827796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"B.o.B","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":5,"lastName":"Klein","length":269.63546,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Nothin' On You [feat. Bruno Mars] (Album Version)","status":200,"ts":1541360115796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Baby Boy Da Prince \/ Mannie Fresh","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":6,"lastName":"Klein","length":235.2322,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Naw Meen","status":200,"ts":1541360384796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Gerry Rafferty","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":7,"lastName":"Klein","length":224.39138,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Don't Close The Door","status":200,"ts":1541360619796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":8,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Error","registration":1540558108796.0,"sessionId":72,"song":null,"status":404,"ts":1541360693796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":9,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Home","registration":1540558108796.0,"sessionId":72,"song":null,"status":200,"ts":1541360696796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"the bird and the bee","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":10,"lastName":"Klein","length":165.642,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Again & Again","status":200,"ts":1541360843796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Blur","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":11,"lastName":"Klein","length":361.58649,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Sing","status":200,"ts":1541361008796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Puerto Rican Power","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":12,"lastName":"Klein","length":305.44934,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Juguete De Nadie","status":200,"ts":1541361369796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Hercules And Love Affair","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":13,"lastName":"Klein","length":471.74485,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Blind (Frankie Knuckles Remix)","status":200,"ts":1541361674796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":14,"lastName":"Klein","length":235.67628,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Kitty Kat","status":200,"ts":1541362145796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Burt Bacharach","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":15,"lastName":"Klein","length":200.54159,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Pacific Coast Highway","status":200,"ts":1541362380796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Common","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":16,"lastName":"Klein","length":144.16934,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Be (Intro)","status":200,"ts":1541362580796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Ra Ra Riot","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":17,"lastName":"Klein","length":152.71138,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Can You Tell","status":200,"ts":1541362724796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Flyleaf","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":18,"lastName":"Klein","length":167.8624,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"There For You","status":200,"ts":1541362876796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Neil Young","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":19,"lastName":"Klein","length":414.69342,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Danger Bird (Album Version)","status":200,"ts":1541363043796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"A Day To Remember","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":20,"lastName":"Klein","length":87.50975,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"You Already Know What You Are","status":200,"ts":1541363457796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Del Tha Funkee Homosapien","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":21,"lastName":"Klein","length":199.07873,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Sleepin' On My Couch","status":200,"ts":1541363544796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Leopoldo Federico","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":22,"lastName":"Klein","length":205.73995,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"La Cachila","status":200,"ts":1541363743796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Moose","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":23,"lastName":"Klein","length":490.21342,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Do You Remember","status":200,"ts":1541363948796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Wyclef Jean","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":24,"lastName":"Klein","length":242.07628,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Knockin' On Heaven's Door","status":200,"ts":1541364438796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Alvin And The Chipmunks","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":25,"lastName":"Klein","length":166.47791,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Coast 2 Coast","status":200,"ts":1541364680796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Anthrax","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":26,"lastName":"Klein","length":458.23955,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Who Cares Wins","status":200,"ts":1541364846796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Beatsteaks","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":27,"lastName":"Klein","length":177.8673,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":72,"song":"Jane Became Insane","status":200,"ts":1541365304796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Nouvelle Vague","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":132.70159,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":249,"song":"Too Drunk Too F****","status":200,"ts":1541372184796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Mastodon","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":1,"lastName":"Simpson","length":218.87955,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":249,"song":"Divinations (Album Version)","status":200,"ts":1541372316796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"The Killers","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":2,"lastName":"Simpson","length":245.99465,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":249,"song":"Sam's Town","status":200,"ts":1541372534796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":253,"song":null,"status":307,"ts":1541373796796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":1,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"Home","registration":1540907087796.0,"sessionId":253,"song":null,"status":200,"ts":1541373956796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":2,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"Logout","registration":1540907087796.0,"sessionId":253,"song":null,"status":307,"ts":1541373957796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":253,"song":null,"status":200,"ts":1541373965796,"userAgent":null,"userId":""} {"artist":"Alanis Morissette","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":0,"lastName":"White","length":175.82975,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":186,"song":"Right Through You (LP Version)","status":200,"ts":1541375113796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"}
452.291005
575
0.696222
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"A Fine Frenzy","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":267.91138,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":256,"song":"Almost Lover (Album Version)","status":200,"ts":1541377992796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Nirvana","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":214.77832,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Serve The Servants","status":200,"ts":1541381242796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Television","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":238.49751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"See No Evil (Remastered LP Version)","status":200,"ts":1541381456796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"JOHN COLTRANE","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":346.43546,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Blues To Bechet (LP Version)","status":200,"ts":1541381694796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"NOFX","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":3,"lastName":"Kirby","length":80.79628,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"It's My Job To Keep Punk Rock Elite","status":200,"ts":1541382040796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Backyardigans","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":4,"lastName":"Kirby","length":158.85016,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Into The Thick Of It!","status":200,"ts":1541382120796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Bruce Springsteen","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":5,"lastName":"Kirby","length":202.84036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Radio Nowhere","status":200,"ts":1541382278796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Maroon 5","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":6,"lastName":"Kirby","length":173.66159,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Harder To Breathe","status":200,"ts":1541382480796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Two Door Cinema Club","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":7,"lastName":"Kirby","length":189.67465,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"What You Know","status":200,"ts":1541382653796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Five Finger Death Punch","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":8,"lastName":"Kirby","length":262.81751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Meet the Monster","status":200,"ts":1541382842796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Josh Turner","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":9,"lastName":"Kirby","length":207.93424,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"What It Ain't","status":200,"ts":1541383104796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"At The Drive-In","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":10,"lastName":"Kirby","length":207.46404,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Sleepwalk Capsules","status":200,"ts":1541383311796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Animal Collective","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":11,"lastName":"Kirby","length":269.81832,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Summertime Clothes","status":200,"ts":1541383518796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Ron Carter","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":12,"lastName":"Kirby","length":497.13587,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"I CAN'T GET STARTED","status":200,"ts":1541383787796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Old 97's","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":13,"lastName":"Kirby","length":231.28771,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Victoria (LP Version)","status":200,"ts":1541384284796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Cyndi Lauper","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":14,"lastName":"Kirby","length":226.32444,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"True Colors","status":200,"ts":1541384515796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Damien Rice","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":15,"lastName":"Kirby","length":276.08771,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Amie","status":200,"ts":1541384741796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Alicia Keys","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":16,"lastName":"Kirby","length":229.0673,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"If I Ain't Got You","status":200,"ts":1541385017796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Lloyd Cole And The Commotions","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":17,"lastName":"Kirby","length":235.31057,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Charlotte Street","status":200,"ts":1541385246796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"John Mayer","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":18,"lastName":"Kirby","length":269.71383,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Heartbreak Warfare","status":200,"ts":1541385481796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Joshua Radin","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":19,"lastName":"Kirby","length":161.69751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"We Are Okay","status":200,"ts":1541385750796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":20,"lastName":"Kirby","length":201.79546,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Revelry","status":200,"ts":1541385911796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Incubus","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":21,"lastName":"Kirby","length":257.25342,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Dig","status":200,"ts":1541386112796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Owl City","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":22,"lastName":"Kirby","length":190.17098,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"Tidal Wave","status":200,"ts":1541386369796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Mediaeval Baebes","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":23,"lastName":"Kirby","length":219.29751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":237,"song":"M\u00c3\u0083\u00c2\u00a4rk Hure V\u00c3\u0083\u00c2\u00a5r Skugga","status":200,"ts":1541386559796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":300.30322,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":226,"song":"The Only One","status":200,"ts":1541386758796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Smith","length":262.73914,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":226,"song":"All My Life","status":200,"ts":1541387058796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Havok","auth":"Logged In","firstName":"Noah","gender":"M","itemInSession":0,"lastName":"Chavez","length":227.68281,"level":"free","location":"Ogden-Clearfield, UT","method":"PUT","page":"NextSong","registration":1540970748796.0,"sessionId":150,"song":"Ivory Tower","status":200,"ts":1541392598796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"94"} {"artist":"John Mayer","auth":"Logged In","firstName":"Noah","gender":"M","itemInSession":1,"lastName":"Chavez","length":250.38322,"level":"free","location":"Ogden-Clearfield, UT","method":"PUT","page":"NextSong","registration":1540970748796.0,"sessionId":150,"song":"Half Of My Heart","status":200,"ts":1541392825796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"94"} {"artist":"The Killers","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":185.33832,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":239,"song":"I Can't Stay","status":200,"ts":1541393054796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Thrice","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":134.60853,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":259,"song":"The Red Death","status":200,"ts":1541393112796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Alicia Keys","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":1,"lastName":"Simpson","length":229.0673,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":259,"song":"If I Ain't Got You","status":200,"ts":1541393246796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":null,"auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":2,"lastName":"Simpson","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Home","registration":1541044398796.0,"sessionId":259,"song":null,"status":200,"ts":1541393249796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Euge Groove","auth":"Logged In","firstName":"Jahiem","gender":"M","itemInSession":0,"lastName":"Miles","length":265.482,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540817347796.0,"sessionId":245,"song":"Tenderly","status":200,"ts":1541394769796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"43"} {"artist":"Metallica \/ Marianne Faithfull","auth":"Logged In","firstName":"Katherine","gender":"F","itemInSession":0,"lastName":"Gay","length":279.11791,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540968306796.0,"sessionId":56,"song":"The Memory Remains","status":200,"ts":1541396838796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_6_8) AppleWebKit\/534.59.10 (KHTML, like Gecko) Version\/5.1.9 Safari\/534.59.10\"","userId":"57"} {"artist":"Nana Caymmi","auth":"Logged In","firstName":"Katherine","gender":"F","itemInSession":1,"lastName":"Gay","length":174.41914,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540968306796.0,"sessionId":56,"song":"Fim De Caso","status":200,"ts":1541397117796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_6_8) AppleWebKit\/534.59.10 (KHTML, like Gecko) Version\/5.1.9 Safari\/534.59.10\"","userId":"57"} {"artist":"Johnny Burnette","auth":"Logged In","firstName":"Katherine","gender":"F","itemInSession":2,"lastName":"Gay","length":134.84363,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540968306796.0,"sessionId":56,"song":"I've Got A Lot Of Things To Do","status":200,"ts":1541397291796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_6_8) AppleWebKit\/534.59.10 (KHTML, like Gecko) Version\/5.1.9 Safari\/534.59.10\"","userId":"57"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Katherine","gender":"F","itemInSession":3,"lastName":"Gay","length":177.94567,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540968306796.0,"sessionId":56,"song":"Fake Tales Of San Francisco","status":200,"ts":1541397425796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_6_8) AppleWebKit\/534.59.10 (KHTML, like Gecko) Version\/5.1.9 Safari\/534.59.10\"","userId":"57"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":224,"song":null,"status":200,"ts":1541399572796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"DeGarmo & Key","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":236.48608,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":224,"song":"I'm Accepted (The Pledge Album Version)","status":200,"ts":1541399606796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":232,"song":null,"status":200,"ts":1541402189796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Extrawelt","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":338.23302,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":232,"song":"Stammgast","status":200,"ts":1541402262796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":260,"song":null,"status":200,"ts":1541404103796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"Logout","registration":1541022995796.0,"sessionId":260,"song":null,"status":307,"ts":1541404104796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":260,"song":null,"status":200,"ts":1541404109796,"userAgent":null,"userId":""} {"artist":"Powderfinger","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":0,"lastName":"Barrett","length":276.68853,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"My Happiness","status":200,"ts":1541407366796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Radiohead","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":1,"lastName":"Barrett","length":247.06567,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Black Star","status":200,"ts":1541407642796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Kid Cudi Vs Crookers","auth":"Logged In","firstName":"Brantley","gender":"M","itemInSession":0,"lastName":"West","length":162.97751,"level":"free","location":"Portland-Vancouver-Hillsboro, OR-WA","method":"PUT","page":"NextSong","registration":1541056614796.0,"sessionId":242,"song":"Day 'N' Nite","status":200,"ts":1541407807796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"28"} {"artist":"Three Days Grace","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":2,"lastName":"Barrett","length":186.90567,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Just Like You","status":200,"ts":1541407889796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Monty Python","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":3,"lastName":"Barrett","length":15.85587,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Comfy Chair (The Final Rip Off Remix)","status":200,"ts":1541408075796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Rise Against","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":4,"lastName":"Barrett","length":241.55383,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Long Forgotten Sons","status":200,"ts":1541408090796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Jimmy Eat World","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":5,"lastName":"Barrett","length":166.00771,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"The Middle","status":200,"ts":1541408331796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Rise Against","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":6,"lastName":"Barrett","length":165.14567,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Under The Knife","status":200,"ts":1541408497796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Chaka Khan","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":7,"lastName":"Barrett","length":280.86812,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Ain't Nobody (Album Version)","status":200,"ts":1541408662796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Paper Lace","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":8,"lastName":"Barrett","length":192.07791,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"The Night Chicago Died","status":200,"ts":1541408942796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":267,"song":null,"status":200,"ts":1541409038796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Pixies","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":9,"lastName":"Barrett","length":113.78893,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Break My Body","status":200,"ts":1541409134796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Wolfgang Gartner","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":10,"lastName":"Barrett","length":415.97342,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Fire Power","status":200,"ts":1541409247796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"No Doubt","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":0,"lastName":"Larson","length":269.73995,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":59,"song":"Sometimes","status":200,"ts":1541409629796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"The Lonely Island \/ Julian Casablancas","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":11,"lastName":"Barrett","length":192.9922,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Boombox","status":200,"ts":1541409662796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Eminem","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":12,"lastName":"Barrett","length":284.18567,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"The Real Slim Shady","status":200,"ts":1541409854796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Martin Gore","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":0,"lastName":"Johnson","length":241.10975,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"By This River","status":200,"ts":1541409990796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Animals","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":13,"lastName":"Barrett","length":242.05016,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"For Miss Caulker (1999 Digital Remaster)","status":200,"ts":1541410138796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":1,"lastName":"Johnson","length":168.64608,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"You've Got The Love","status":200,"ts":1541410231796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Home","registration":1540266185796.0,"sessionId":241,"song":null,"status":200,"ts":1541410265796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Hot Water Music","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":14,"lastName":"Barrett","length":157.85751,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"The Sense","status":200,"ts":1541410380796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Bill Withers","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":2,"lastName":"Johnson","length":383.73832,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Make Love To Your Mind","status":200,"ts":1541410399796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"311","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":15,"lastName":"Barrett","length":194.32444,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Eons","status":200,"ts":1541410537796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Bloc Party","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":16,"lastName":"Barrett","length":215.11791,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"The Pioneers","status":200,"ts":1541410731796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Nino Bravo","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":3,"lastName":"Johnson","length":218.48771,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Amanecer","status":200,"ts":1541410782796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Jos\u00c3\u0083\u00c2\u00a9 Gonz\u00c3\u0083\u00c2\u00a1lez","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":17,"lastName":"Barrett","length":143.93424,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"The Nest","status":200,"ts":1541410946796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Taking Back Sunday","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":4,"lastName":"Johnson","length":249.99138,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"This Photograph Is Proof {I Know You Know] (Album Version)","status":200,"ts":1541411000796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":18,"lastName":"Barrett","length":207.64689,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Better Together","status":200,"ts":1541411089796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"The Rolling Stones","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":5,"lastName":"Johnson","length":274.1024,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Stop Breaking Down","status":200,"ts":1541411249796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Euge Groove","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":19,"lastName":"Barrett","length":265.482,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Tenderly","status":200,"ts":1541411296796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"School Of Seven Bells","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":262.37342,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":254,"song":"Chain","status":200,"ts":1541411470796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"P!nk","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":6,"lastName":"Johnson","length":227.02975,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Glitter In The Air","status":200,"ts":1541411523796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Nancy Wilson","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":20,"lastName":"Barrett","length":122.77506,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"I Believe In You","status":200,"ts":1541411561796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Enrique Iglesias","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":21,"lastName":"Barrett","length":235.17995,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Ring My Bells","status":200,"ts":1541411683796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Katie Melua","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":7,"lastName":"Johnson","length":242.83383,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Scary Films","status":200,"ts":1541411750796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Harmonia","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":22,"lastName":"Barrett","length":655.77751,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Sehr kosmisch","status":200,"ts":1541411918796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"The RH Factor","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":8,"lastName":"Johnson","length":233.35138,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Hold On","status":200,"ts":1541411992796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Moose","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":490.21342,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":267,"song":"Do You Remember","status":200,"ts":1541412174796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"KATAKLYSM","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":9,"lastName":"Johnson","length":162.92526,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"In Shadows And Dust","status":200,"ts":1541412225796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":10,"lastName":"Johnson","length":159.84281,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Everybody's Changing","status":200,"ts":1541412387796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":11,"lastName":"Johnson","length":258.55955,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Cosmic Love","status":200,"ts":1541412546796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Placebo","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":23,"lastName":"Barrett","length":254.45832,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Taste In Men","status":200,"ts":1541412573796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"DJ Dizzy","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":221.1522,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":267,"song":"Sexy Bitch","status":200,"ts":1541412664796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Camera Obscura","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":12,"lastName":"Johnson","length":188.02893,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Anti-Western","status":200,"ts":1541412804796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Nick Cave & The Bad Seeds","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":24,"lastName":"Barrett","length":265.27302,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Spell","status":200,"ts":1541412827796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Queens Of The Stone Age","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":364.90404,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":267,"song":"God Is On The Radio","status":200,"ts":1541412885796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":13,"lastName":"Johnson","length":494.99383,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Bleed It Out [Live At Milton Keynes]","status":200,"ts":1541412992796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":25,"lastName":"Barrett","length":239.3073,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"You're The One","status":200,"ts":1541413092796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":null,"auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":26,"lastName":"Barrett","length":null,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540685364796.0,"sessionId":129,"song":null,"status":200,"ts":1541413101796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"mewithoutYou","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":311.562,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":267,"song":"Bullet To Binary (Pt. Two)","status":200,"ts":1541413249796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The New Pornographers","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":27,"lastName":"Barrett","length":189.02159,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"All The Things That Go To Make Heaven And Earth","status":200,"ts":1541413331796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Edward Sharpe & The Magnetic Zeros","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":14,"lastName":"Johnson","length":306.31138,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Home","status":200,"ts":1541413486796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Diego Torres","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":28,"lastName":"Barrett","length":227.18649,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Sue\u00c3\u0083\u00c2\u00b1os","status":200,"ts":1541413520796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Francisca Valenzuela","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":29,"lastName":"Barrett","length":174.70649,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Mu\u00c3\u0083\u00c2\u00a9rdete la lengua","status":200,"ts":1541413747796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Pendulum","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":15,"lastName":"Johnson","length":315.71546,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"The Other Side (album version)","status":200,"ts":1541413792796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Local Natives","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":30,"lastName":"Barrett","length":330.89261,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Shape Shifter","status":200,"ts":1541413921796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":16,"lastName":"Johnson","length":416.522,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Emotion","status":200,"ts":1541414107796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Soda Stereo","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":31,"lastName":"Barrett","length":211.61751,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Danza Rota","status":200,"ts":1541414251796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"The Cardigans","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":32,"lastName":"Barrett","length":198.21669,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Lovefool","status":200,"ts":1541414462796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":null,"auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":33,"lastName":"Barrett","length":null,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540685364796.0,"sessionId":129,"song":null,"status":200,"ts":1541414463796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"ETERNAL FEATURING BEBE WINANS","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":17,"lastName":"Johnson","length":218.40934,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"I Wanna Be The Only One","status":200,"ts":1541414523796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":34,"lastName":"Barrett","length":201.79546,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Revelry","status":200,"ts":1541414660796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Julie Doiron","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":18,"lastName":"Johnson","length":165.92934,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Me and My Friend","status":200,"ts":1541414741796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":269,"song":null,"status":307,"ts":1541414804796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":269,"song":null,"status":200,"ts":1541414811796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kinky","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":211.90485,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Cornman","status":200,"ts":1541414815796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"LU","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":35,"lastName":"Barrett","length":321.54077,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Una Confusion","status":200,"ts":1541414861796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":19,"lastName":"Johnson","length":233.69098,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Invalid","status":200,"ts":1541414906796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Nickel Creek","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":3,"lastName":"Kirby","length":301.40036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"The Lighthouse's Tale","status":200,"ts":1541415026796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Massive Attack","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":20,"lastName":"Johnson","length":288.65261,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"One Love","status":200,"ts":1541415139796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Cut Copy","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":36,"lastName":"Barrett","length":283.76771,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Strangers In The Wind","status":200,"ts":1541415182796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Straylight Run","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":4,"lastName":"Kirby","length":241.44934,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Existentialism On Prom Night (Album Version)","status":200,"ts":1541415327796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":5,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":269,"song":null,"status":200,"ts":1541415367796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":6,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Settings","registration":1541022995796.0,"sessionId":269,"song":null,"status":200,"ts":1541415367796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Albert Hammond","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":21,"lastName":"Johnson","length":177.78893,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Echame A Mi La Culpa","status":200,"ts":1541415427796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Hercules And Love Affair","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":37,"lastName":"Barrett","length":376.29342,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":129,"song":"Blind (Full Album Version)","status":200,"ts":1541415465796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":null,"auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":38,"lastName":"Barrett","length":null,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Error","registration":1540685364796.0,"sessionId":129,"song":null,"status":404,"ts":1541415469796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Left Lane Cruiser","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":7,"lastName":"Kirby","length":183.27465,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Amerika","status":200,"ts":1541415568796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"UB40","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":22,"lastName":"Johnson","length":185.10322,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Come Back Darling","status":200,"ts":1541415604796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Amon Amarth","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":8,"lastName":"Kirby","length":357.22404,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Fate Of Norns","status":200,"ts":1541415751796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Queensryche","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":23,"lastName":"Johnson","length":347.81995,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Silent Lucidity (2002 Digital Remaster)","status":200,"ts":1541415789796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Winds Of Plague","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":9,"lastName":"Kirby","length":148.08771,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Reloaded","status":200,"ts":1541416108796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Jackson 5","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":24,"lastName":"Johnson","length":174.10567,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Ben","status":200,"ts":1541416136796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Feist","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":10,"lastName":"Kirby","length":184.94649,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"My Moon My Man","status":200,"ts":1541416256796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Jos\u00c3\u0083\u00c2\u00a9 Gonzalez","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":25,"lastName":"Johnson","length":158.48444,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Heartbeats","status":200,"ts":1541416310796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Flobots","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":11,"lastName":"Kirby","length":205.68771,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Handlebars (UK Radio Edit)","status":200,"ts":1541416440796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Teriyaki Boyz","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":26,"lastName":"Johnson","length":253.77914,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Heartbreaker","status":200,"ts":1541416468796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":12,"lastName":"Kirby","length":239.3073,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"You're The One","status":200,"ts":1541416645796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Young Money featuring Lloyd","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":27,"lastName":"Johnson","length":196.33587,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"BedRock (Radio Edit) (feat.Lloyd)","status":200,"ts":1541416721796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Pussycat Dolls","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":13,"lastName":"Kirby","length":245.18485,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"When I Grow Up","status":200,"ts":1541416884796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Koopsta Knicca","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":28,"lastName":"Johnson","length":206.78485,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Top Secret","status":200,"ts":1541416917796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Knack","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":29,"lastName":"Johnson","length":141.58322,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Let Me Out","status":200,"ts":1541417123796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Prodigy","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":14,"lastName":"Kirby","length":215.77098,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Omen","status":200,"ts":1541417129796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"ZZ Top","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":30,"lastName":"Johnson","length":187.8722,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Avalon Hideaway (LP Version)","status":200,"ts":1541417264796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Caifanes","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":15,"lastName":"Kirby","length":263.33995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Cuentame Tu Vida","status":200,"ts":1541417344796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":16,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":269,"song":null,"status":200,"ts":1541417402796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Britt Nicole","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":31,"lastName":"Johnson","length":232.85506,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":222,"song":"Like A Star","status":200,"ts":1541417451796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":32,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"Logout","registration":1540809153796.0,"sessionId":222,"song":null,"status":307,"ts":1541417452796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":17,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Settings","registration":1541022995796.0,"sessionId":269,"song":null,"status":200,"ts":1541417462796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":18,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Settings","registration":1541022995796.0,"sessionId":269,"song":null,"status":200,"ts":1541417478796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":33,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":222,"song":null,"status":200,"ts":1541417518796,"userAgent":null,"userId":""} {"artist":"Jimmy Buffett","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":19,"lastName":"Kirby","length":209.00526,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"He Went To Paris","status":200,"ts":1541417607796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Counting Crows","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":20,"lastName":"Kirby","length":272.79628,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Mr. Jones","status":200,"ts":1541417816796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"8Ball & MJG","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":21,"lastName":"Kirby","length":48.14322,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Intro (Explicit Album Version)","status":200,"ts":1541418088796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Sin\u00c3\u0083\u00c2\u00a9ad O'Connor","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":22,"lastName":"Kirby","length":282.51383,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"I Want Your (Hands On Me)","status":200,"ts":1541418136796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Vince Guaraldi Trio","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":23,"lastName":"Kirby","length":368.29995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Christmastime Is Here","status":200,"ts":1541418418796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"B*Witched","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":24,"lastName":"Kirby","length":172.06812,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"C'est La Vie","status":200,"ts":1541418786796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Gyptian","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":25,"lastName":"Kirby","length":211.04281,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Love Against the Wall","status":200,"ts":1541418958796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Ataris","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":26,"lastName":"Kirby","length":179.722,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"I Won't Spend Another Night Alone","status":200,"ts":1541419169796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Adam Green","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":27,"lastName":"Kirby","length":143.49016,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"You Get So Lucky","status":200,"ts":1541419348796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Marilyn Manson","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":28,"lastName":"Kirby","length":247.01342,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Personal Jesus","status":200,"ts":1541419491796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Bobby Blue Bland","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":29,"lastName":"Kirby","length":141.13914,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"I Pity the Fool","status":200,"ts":1541419738796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"David Banner","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":30,"lastName":"Kirby","length":232.75057,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Play","status":200,"ts":1541419879796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"We The Kings featuring Demi Lovato","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":31,"lastName":"Kirby","length":231.78404,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"We'll Be A Dream (featuring Demi Lovato)","status":200,"ts":1541420111796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Emiliana Torrini","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":32,"lastName":"Kirby","length":383.50322,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Birds","status":200,"ts":1541420342796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Garbage","auth":"Logged In","firstName":"Shakira","gender":"F","itemInSession":0,"lastName":"Hunt","length":277.39383,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540636000796.0,"sessionId":83,"song":"Temptation Waits","status":200,"ts":1541420496796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"84"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":33,"lastName":"Kirby","length":268.61669,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"New Divide (Album Version)","status":200,"ts":1541420725796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Darius Rucker","auth":"Logged In","firstName":"Shakira","gender":"F","itemInSession":1,"lastName":"Hunt","length":217.44281,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540636000796.0,"sessionId":83,"song":"It Won't Be Like This For Long","status":200,"ts":1541420773796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"84"} {"artist":"The Strokes","auth":"Logged In","firstName":"Shakira","gender":"F","itemInSession":2,"lastName":"Hunt","length":230.1122,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540636000796.0,"sessionId":83,"song":"Killing Lies","status":200,"ts":1541420990796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"84"} {"artist":"Los Bunkers","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":34,"lastName":"Kirby","length":209.97179,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Te Vistes Y Te Vas","status":200,"ts":1541420993796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":35,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Help","registration":1541022995796.0,"sessionId":269,"song":null,"status":200,"ts":1541420996796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Ween","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":36,"lastName":"Kirby","length":242.59873,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"I'm Holding You (LP Version)","status":200,"ts":1541421202796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Weird Al\" Yankovic","auth":"Logged In","firstName":"Shakira","gender":"F","itemInSession":3,"lastName":"Hunt","length":170.21342,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540636000796.0,"sessionId":83,"song":"White & Nerdy (Parody of \"Ridin'\" by Chamillionaire featuring Krayzie Bone)","status":200,"ts":1541421220796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"84"} {"artist":"The Moody Blues","auth":"Logged In","firstName":"Shakira","gender":"F","itemInSession":4,"lastName":"Hunt","length":258.71628,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540636000796.0,"sessionId":83,"song":"Tuesday Afternoon","status":200,"ts":1541421390796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"84"} {"artist":"DESTRUCTION","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":37,"lastName":"Kirby","length":226.97751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Dictators Of Cruelty","status":200,"ts":1541421444796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Carla Bruni","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":38,"lastName":"Kirby","length":163.02975,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Quelqu'un M'a Dit (Album Version)","status":200,"ts":1541421670796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"En Vogue","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":39,"lastName":"Kirby","length":289.01832,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Don't Let Go (Love)","status":200,"ts":1541421833796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Eminem","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":40,"lastName":"Kirby","length":250.8273,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Mockingbird","status":200,"ts":1541422122796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":41,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"Logout","registration":1541022995796.0,"sessionId":269,"song":null,"status":307,"ts":1541422123796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":42,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":269,"song":null,"status":200,"ts":1541422142796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":43,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":269,"song":null,"status":307,"ts":1541422143796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":44,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":269,"song":null,"status":200,"ts":1541422145796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Showbread","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":45,"lastName":"Kirby","length":287.29424,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"The Missing Wife","status":200,"ts":1541422372796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Tracie Spencer","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":46,"lastName":"Kirby","length":272.45669,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"My First Broken Heart","status":200,"ts":1541422659796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":47,"lastName":"Kirby","length":261.74649,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Halo","status":200,"ts":1541422931796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":48,"lastName":"Kirby","length":207.64689,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Better Together","status":200,"ts":1541423192796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Michael Bubl\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":49,"lastName":"Kirby","length":226.0371,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Smile (Live)","status":200,"ts":1541423399796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Epica","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":50,"lastName":"Kirby","length":303.20281,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Martyr of the Free Word","status":200,"ts":1541423625796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"A Silent Film","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":51,"lastName":"Kirby","length":222.45832,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"You Will Leave a Mark","status":200,"ts":1541423928796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":52,"lastName":"Kirby","length":348.57751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Undo","status":200,"ts":1541424150796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Vampire Weekend","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":53,"lastName":"Kirby","length":214.7522,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Cape Cod Kwassa Kwassa (Album)","status":200,"ts":1541424498796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Rammstein","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":54,"lastName":"Kirby","length":201.50812,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"B\u00c3\u0083\u00c2\u00bcck Dich","status":200,"ts":1541424712796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Junkie XL","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":55,"lastName":"Kirby","length":221.77914,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Broken (featuring Grant Nicholas) (Album Version)","status":200,"ts":1541424913796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Third Eye Blind","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":56,"lastName":"Kirby","length":232.77669,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Company","status":200,"ts":1541425134796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Evanescence","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":57,"lastName":"Kirby","length":236.12036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Bring Me To Life","status":200,"ts":1541425366796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":58,"lastName":"Kirby","length":65.802,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Cupid","status":200,"ts":1541425602796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Fergie","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":59,"lastName":"Kirby","length":240.48281,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Clumsy","status":200,"ts":1541425667796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":60,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Downgrade","registration":1541022995796.0,"sessionId":269,"song":null,"status":200,"ts":1541425712796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":61,"lastName":"Kirby","length":189.98812,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"LDN","status":200,"ts":1541425907796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Black Seeds","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":62,"lastName":"Kirby","length":257.98485,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Dance Dance","status":200,"ts":1541426096796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Cassie","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":63,"lastName":"Kirby","length":212.1922,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Call U Out (Album Version)","status":200,"ts":1541426353796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Rolling Stones","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":64,"lastName":"Kirby","length":231.78404,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Too Tough (1994 Digital Remaster)","status":200,"ts":1541426565796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Eminem","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":65,"lastName":"Kirby","length":251.55873,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Without Me","status":200,"ts":1541426796796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":66,"lastName":"Kirby","length":175.80363,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Sweet Hitch-Hiker","status":200,"ts":1541427047796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Heltah Skeltah","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":67,"lastName":"Kirby","length":165.642,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Place To Be (Explicit)","status":200,"ts":1541427222796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Redman","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":68,"lastName":"Kirby","length":251.53261,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Pick It Up","status":200,"ts":1541427387796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Camila","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":69,"lastName":"Kirby","length":258.53342,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Alejate De Mi","status":200,"ts":1541427638796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":268,"song":null,"status":200,"ts":1541427747796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Pearl Jam","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":67.44771,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":268,"song":"Encore Break","status":200,"ts":1541427789796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Faith No More","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":249.86077,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":268,"song":"Last Cup Of Sorrow","status":200,"ts":1541427856796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Liquid Tension Experiment","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":70,"lastName":"Kirby","length":535.35302,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Paradigm Shift","status":200,"ts":1541427896796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":null,"level":"free","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":273,"song":null,"status":200,"ts":1541427929796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Fleetwood Mac","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":71,"lastName":"Kirby","length":265.92608,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"World Turning (LP Version)","status":200,"ts":1541428431796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Bell","length":null,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"GET","page":"Home","registration":1540991795796.0,"sessionId":90,"song":null,"status":200,"ts":1541428525796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 10.0; Windows NT 6.2; WOW64; Trident\/6.0)","userId":"91"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Bell","length":253.90975,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540991795796.0,"sessionId":90,"song":"Midnight Special","status":200,"ts":1541428530796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 10.0; Windows NT 6.2; WOW64; Trident\/6.0)","userId":"91"} {"artist":"The Ruts","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":72,"lastName":"Kirby","length":338.96444,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"West One (Shine On Me)","status":200,"ts":1541428696796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Steve Miller Band","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Bell","length":263.96689,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540991795796.0,"sessionId":90,"song":"The Joker","status":200,"ts":1541428783796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 10.0; Windows NT 6.2; WOW64; Trident\/6.0)","userId":"91"} {"artist":"The Kingstonians","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":172.90404,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":263,"song":"Winey Winey","status":200,"ts":1541428980796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Staind","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":73,"lastName":"Kirby","length":239.5424,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Everything Changes (Album Version)","status":200,"ts":1541429034796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Bon Jovi","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Bell","length":224.522,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540991795796.0,"sessionId":90,"song":"It's My Life","status":200,"ts":1541429046796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 10.0; Windows NT 6.2; WOW64; Trident\/6.0)","userId":"91"} {"artist":"Chris Brown featuring T-Pain","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":74,"lastName":"Kirby","length":250.67057,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Kiss Kiss","status":200,"ts":1541429273796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Regina Spektor","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":0,"lastName":"Griffin","length":191.08526,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"The Calculation (Album Version)","status":200,"ts":1541429341796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Lamb","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":75,"lastName":"Kirby","length":1031.75791,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Feela","status":200,"ts":1541429523796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Octopus Project","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":1,"lastName":"Griffin","length":250.95791,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"All Of The Champs That Ever Lived","status":200,"ts":1541429532796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Tegan And Sara","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":2,"lastName":"Griffin","length":180.06159,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"So Jealous","status":200,"ts":1541429782796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Dragonette","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":3,"lastName":"Griffin","length":153.39057,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Okay Dolores","status":200,"ts":1541429962796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Lil Wayne \/ Eminem","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":4,"lastName":"Griffin","length":229.58975,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Drop The World","status":200,"ts":1541430115796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Soulja Boy Tell'em","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":5,"lastName":"Griffin","length":201.11628,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Let Me Get Em","status":200,"ts":1541430344796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Audio Adrenaline","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":202.52689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Free Ride","status":200,"ts":1541430369796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bodo Wartke","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":6,"lastName":"Griffin","length":645.27628,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Liebeslied (Sprachen: Deutsch_ Englisch_ Franz\u00c3\u0083\u00c2\u00b6sisch_ Italienisch_ Spanisch_ Holl\u00c3\u0083\u00c2\u00a4ndisch_ Japanisch_ Russisch_ Griechisch_ Klingonisch_ Hessisch)","status":200,"ts":1541430545796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Prince & The New Power Generation [with Eric Leeds on Flute]","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":76,"lastName":"Kirby","length":272.63955,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Gett Off","status":200,"ts":1541430554796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Format","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":208.24771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Inches And Falling (I Love_ Love)","status":200,"ts":1541430571796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":219,"song":null,"status":200,"ts":1541430603796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":214.93506,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":219,"song":"Pump It","status":200,"ts":1541430649796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Wilco","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":188.83873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Heavy metal drummer","status":200,"ts":1541430779796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"NOFX","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":77,"lastName":"Kirby","length":54.59546,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Monosyllabic Girl","status":200,"ts":1541430826796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":274,"song":null,"status":200,"ts":1541430859796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cabaret Voltaire","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":430.602,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":274,"song":"Playing For Time","status":200,"ts":1541430874796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Air","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":78,"lastName":"Kirby","length":244.50567,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Venus","status":200,"ts":1541430880796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":249.75628,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Til Kingdom Come","status":200,"ts":1541430967796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Rosana","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":79,"lastName":"Kirby","length":330.1873,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Llegaremos a tiempo","status":200,"ts":1541431124796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Evanescence","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":7,"lastName":"Griffin","length":237.11302,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Bring Me To Life","status":200,"ts":1541431190796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":80,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Settings","registration":1541022995796.0,"sessionId":269,"song":null,"status":200,"ts":1541431201796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":81,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Help","registration":1541022995796.0,"sessionId":269,"song":null,"status":200,"ts":1541431201796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Frumpies","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":134.47791,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Fuck Kitty","status":200,"ts":1541431216796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Plies","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":0,"lastName":"Gutierrez","length":278.22975,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":208,"song":"Somebody (Loves You) (Explicit Album Version)","status":200,"ts":1541431327796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Tit\u00c3\u0083\u00c2\u00a3s","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":131.00363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Pol\u00c3\u0083\u00c2\u00adcia","status":200,"ts":1541431350796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Van Halen","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":8,"lastName":"Griffin","length":243.17342,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Good Enough","status":200,"ts":1541431427796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Snow Patrol","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":82,"lastName":"Kirby","length":307.59138,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Engines","status":200,"ts":1541431454796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":83,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Downgrade","registration":1541022995796.0,"sessionId":269,"song":null,"status":200,"ts":1541431456796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":84,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":269,"song":null,"status":200,"ts":1541431456796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kiss","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":268.30322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"I Was Made For Lovin' You","status":200,"ts":1541431481796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Academy Is...","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":9,"lastName":"Griffin","length":209.76281,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Paper Chase (Album Version)","status":200,"ts":1541431670796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Prodigy","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":414.11873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Weather Experience (Top Buzz Remix)(Remastered)","status":200,"ts":1541431749796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bill Withers","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":85,"lastName":"Kirby","length":383.73832,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":269,"song":"Make Love To Your Mind","status":200,"ts":1541431761796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":10,"lastName":"Griffin","length":239.3073,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"You're The One","status":200,"ts":1541431879796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Far East Movement featuring Wiz Khalifa and Bionik","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":11,"lastName":"Griffin","length":265.50812,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Lowridin","status":200,"ts":1541432118796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Deep Dish","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":439.92771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Sacramento (Club Mix Edit)","status":200,"ts":1541432163796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Amon Amarth","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":12,"lastName":"Griffin","length":238.52363,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"The Hero","status":200,"ts":1541432383796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Jim White","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":396.22485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Still Waters","status":200,"ts":1541432602796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":13,"lastName":"Griffin","length":259.47383,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"The Good Times Are Killing Me","status":200,"ts":1541432621796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bad Company","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":14,"lastName":"Griffin","length":246.96118,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Morning Sun","status":200,"ts":1541432880796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":15,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Settings","registration":1541057188796.0,"sessionId":23,"song":null,"status":200,"ts":1541432938796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":236.09424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Canada","status":200,"ts":1541432998796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bodyrox","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":16,"lastName":"Griffin","length":490.78812,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Yeah Yeah","status":200,"ts":1541433126796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Louise Attaque","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":177.76281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Est-ce que tu m'aimes encore ?","status":200,"ts":1541433234796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Home","registration":1540266185796.0,"sessionId":272,"song":null,"status":200,"ts":1541433408796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"The Pussycat Dolls \/ Busta Rhymes","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":12,"lastName":"Harrell","length":272.14322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Don't Cha","status":200,"ts":1541433411796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Thursday","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":0,"lastName":"Klein","length":250.17424,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Signals Over The Air","status":200,"ts":1541433477796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Alberto Plaza","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":17,"lastName":"Griffin","length":291.5522,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Yo Te Seguire (vivo)","status":200,"ts":1541433616796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":1,"lastName":"Cruz","length":202.73587,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":272,"song":"You Know I'm No Good","status":200,"ts":1541433665796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Musiq \/ DJ Aktive \/ Carol Riddick","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":13,"lastName":"Harrell","length":162.7424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Soulstar","status":200,"ts":1541433683796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Eels","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":1,"lastName":"Klein","length":193.27955,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Guest List","status":200,"ts":1541433727796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":14,"lastName":"Harrell","length":239.3073,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"You're The One","status":200,"ts":1541433845796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"matchbox twenty","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":18,"lastName":"Griffin","length":225.95873,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"3AM (LP Version)","status":200,"ts":1541433907796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Coldplay","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":2,"lastName":"Klein","length":311.27465,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"The Scientist","status":200,"ts":1541433920796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Scissor Sisters","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":15,"lastName":"Harrell","length":271.85587,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Take Your Mama","status":200,"ts":1541434084796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Rob Zombie","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":19,"lastName":"Griffin","length":222.9024,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Dragula","status":200,"ts":1541434132796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Rilo Kiley","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":3,"lastName":"Klein","length":279.06567,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"A Better Son\/Daughter","status":200,"ts":1541434231796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Klaus Doldinger's Passport","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":20,"lastName":"Griffin","length":460.43383,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Fairy Tale","status":200,"ts":1541434354796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Christian Anders","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":16,"lastName":"Harrell","length":334.05342,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Nie Mehr Allein","status":200,"ts":1541434355796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Ashanti","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":4,"lastName":"Klein","length":282.46159,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"VooDoo","status":200,"ts":1541434510796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Placebo","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":324.0224,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":280,"song":"Passive Aggressive","status":200,"ts":1541434643796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":17,"lastName":"Harrell","length":277.15873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1541434689796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"dEUS","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":5,"lastName":"Klein","length":299.83302,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Secret Hell","status":200,"ts":1541434792796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Two Door Cinema Club","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":21,"lastName":"Griffin","length":175.43791,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"I Can Talk","status":200,"ts":1541434814796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"J. Karjalainen & Mustat Lasit","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":18,"lastName":"Harrell","length":336.74404,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Sinisten t\u00c3\u0083\u00c2\u00a4htien alla","status":200,"ts":1541434966796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":22,"lastName":"Griffin","length":224.67873,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Secrets","status":200,"ts":1541434989796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Grascals","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":6,"lastName":"Klein","length":224.13016,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Where Corn Don't Grow","status":200,"ts":1541435091796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Enya","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":23,"lastName":"Griffin","length":212.29669,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Boadicea","status":200,"ts":1541435213796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":19,"lastName":"Harrell","length":311.27465,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"The Scientist","status":200,"ts":1541435302796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Vienna Teng","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":7,"lastName":"Klein","length":204.25098,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"The Last Snowfall","status":200,"ts":1541435315796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Beck","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":24,"lastName":"Griffin","length":211.1473,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Girl","status":200,"ts":1541435425796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Chuck Berry","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":8,"lastName":"Klein","length":147.06893,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Roll Over Beethoven","status":200,"ts":1541435519796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Arkona","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":20,"lastName":"Harrell","length":326.94812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Vosstanie Roda","status":200,"ts":1541435613796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Vampire Weekend","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":25,"lastName":"Griffin","length":243.04281,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"The Kids Don\u0019t Stand A Chance (Album)","status":200,"ts":1541435636796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Creed","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":9,"lastName":"Klein","length":295.3922,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"My Sacrifice","status":200,"ts":1541435666796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Bryan Adams","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":26,"lastName":"Griffin","length":231.99302,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Fearless","status":200,"ts":1541435879796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Deerhunter","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":21,"lastName":"Harrell","length":325.17179,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Neither Of Us_ Uncertainly","status":200,"ts":1541435939796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Angels and Airwaves","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":10,"lastName":"Klein","length":259.44771,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Sirens","status":200,"ts":1541435961796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Incubus","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":27,"lastName":"Griffin","length":168.6722,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"I Miss You","status":200,"ts":1541436110796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Tab Benoit","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":11,"lastName":"Klein","length":221.09995,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Jambalaya","status":200,"ts":1541436220796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Franz Ferdinand","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":22,"lastName":"Harrell","length":206.28853,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Call Me","status":200,"ts":1541436264796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Derek & The Dominos","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":28,"lastName":"Griffin","length":382.37995,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Keep On Growing","status":200,"ts":1541436278796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":12,"lastName":"Klein","length":348.57751,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Undo","status":200,"ts":1541436441796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Little Tony","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":23,"lastName":"Harrell","length":183.84934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Cuore Matto","status":200,"ts":1541436470796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Police","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":24,"lastName":"Harrell","length":289.85424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"So Lonely","status":200,"ts":1541436653796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Mariza","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":29,"lastName":"Griffin","length":208.77016,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Loucura","status":200,"ts":1541436660796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Say Anything","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":13,"lastName":"Klein","length":208.77016,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Walk Through Hell (featuring Max Bemis Acoustic Exclusive)","status":200,"ts":1541436789796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Yung Berg","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":30,"lastName":"Griffin","length":230.63465,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Do That There (featuring Dude 'N Nem)","status":200,"ts":1541436868796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":null,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1541032432796.0,"sessionId":236,"song":null,"status":200,"ts":1541436902796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Supertramp","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":25,"lastName":"Harrell","length":273.18812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Bloody Well Right","status":200,"ts":1541436942796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Framing Hanley","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":14,"lastName":"Klein","length":230.08608,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Alone In This Bed (Capeside)","status":200,"ts":1541436997796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":31,"lastName":"Griffin","length":348.57751,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Undo","status":200,"ts":1541437098796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Wilson Simonal","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":26,"lastName":"Harrell","length":146.75546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Tudo De Voc\u00c3\u0083\u00c2\u00aa","status":200,"ts":1541437215796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Pillar","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":15,"lastName":"Klein","length":190.9024,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Frontline","status":200,"ts":1541437227796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Streetlight Manifesto","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":27,"lastName":"Harrell","length":313.18159,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"A Moment Of Silence (Album Version)","status":200,"ts":1541437361796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kanye West \/ T-Pain","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":16,"lastName":"Klein","length":207.04608,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Good Life","status":200,"ts":1541437417796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"George Michael","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":32,"lastName":"Griffin","length":276.50567,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"I Want Your Sex","status":200,"ts":1541437446796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Garbage","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":17,"lastName":"Klein","length":258.7424,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Stupid Girl","status":200,"ts":1541437624796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Tom Petty And The Heartbreakers","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":28,"lastName":"Harrell","length":180.94975,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"You're Gonna Get It (Album Version)","status":200,"ts":1541437674796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Max Richter","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":33,"lastName":"Griffin","length":193.38404,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":23,"song":"Organum","status":200,"ts":1541437722796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":34,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Error","registration":1541057188796.0,"sessionId":23,"song":null,"status":404,"ts":1541437724796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Winans","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":29,"lastName":"Harrell","length":385.56689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Prone To Wander (Album Version)","status":200,"ts":1541437854796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Calle 13","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":18,"lastName":"Klein","length":211.06893,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Pi-di-di-di","status":200,"ts":1541437882796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Decemberists","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":0,"lastName":"Taylor","length":421.85098,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":171,"song":"I Was Meant For the Stage","status":200,"ts":1541437909796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":null,"auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":1,"lastName":"Taylor","length":null,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"Logout","registration":1540992766796.0,"sessionId":171,"song":null,"status":307,"ts":1541437910796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":171,"song":null,"status":200,"ts":1541437923796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":171,"song":null,"status":307,"ts":1541437924796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":4,"lastName":"Taylor","length":null,"level":"free","location":"St. Louis, MO-IL","method":"GET","page":"Home","registration":1540992766796.0,"sessionId":171,"song":null,"status":200,"ts":1541437943796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"Mae","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":19,"lastName":"Klein","length":230.13832,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"We're So Far Away","status":200,"ts":1541438093796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Girl Talk","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":30,"lastName":"Harrell","length":173.24363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Give and Go","status":200,"ts":1541438239796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Helloween","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":20,"lastName":"Klein","length":309.21098,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Where The Rain Grows","status":200,"ts":1541438323796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"ATB","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":5,"lastName":"Taylor","length":248.21506,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":171,"song":"Killer","status":200,"ts":1541438330796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"The Tangent","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":31,"lastName":"Harrell","length":270.31465,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"After Rubycon (live)","status":200,"ts":1541438412796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Turing Machine","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":6,"lastName":"Taylor","length":522.762,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":171,"song":"Robotronic","status":200,"ts":1541438578796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"Justin Timberlake","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":21,"lastName":"Klein","length":294.86975,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Se\u00c3\u0083\u00c2\u00b1orita","status":200,"ts":1541438632796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Panic At The Disco","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":32,"lastName":"Harrell","length":259.29098,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Behind The Sea [Live In Chicago]","status":200,"ts":1541438682796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":33,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Downgrade","registration":1540472624796.0,"sessionId":147,"song":null,"status":200,"ts":1541438743796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Me First And The Gimme Gimmes","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":22,"lastName":"Klein","length":145.78893,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Good Bye Earl","status":200,"ts":1541438926796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Will.I.Am","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":34,"lastName":"Harrell","length":236.93016,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Invisible","status":200,"ts":1541438941796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Usher","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":23,"lastName":"Klein","length":224.10404,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Hey Daddy (Daddy's Home)","status":200,"ts":1541439071796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Alicia Keys","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":7,"lastName":"Taylor","length":229.0673,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":171,"song":"If I Ain't Got You","status":200,"ts":1541439100796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"The Red Jumpsuit Apparatus","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":35,"lastName":"Harrell","length":191.84281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Face Down (Album Version)","status":200,"ts":1541439177796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"John Mayer","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":24,"lastName":"Klein","length":201.16853,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Waiting On The World To Change","status":200,"ts":1541439295796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":36,"lastName":"Harrell","length":131.3171,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Kiss With A Fist","status":200,"ts":1541439368796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Cute Lepers","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":25,"lastName":"Klein","length":195.52608,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Prove It","status":200,"ts":1541439496796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Bruce Springsteen","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":37,"lastName":"Harrell","length":304.43057,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Into The Fire","status":200,"ts":1541439499796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Carla Bruni","auth":"Logged In","firstName":"Sienna","gender":"F","itemInSession":0,"lastName":"Colon","length":163.02975,"level":"free","location":"Las Cruces, NM","method":"PUT","page":"NextSong","registration":1540013692796.0,"sessionId":159,"song":"Quelqu'un M'a Dit (Album Version)","status":200,"ts":1541439635796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"81"} {"artist":"Nando Reis","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":26,"lastName":"Klein","length":245.96853,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Relic\u00c3\u0083\u00c2\u00a1rio","status":200,"ts":1541439691796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Home","registration":1540664184796.0,"sessionId":231,"song":null,"status":200,"ts":1541439801796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Holly Brook","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":38,"lastName":"Harrell","length":250.80118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"All Will Be Forgotten (Album Version)","status":200,"ts":1541439803796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Sun Kil Moon","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Graves","length":196.62322,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"Tiny Cities Made Of Ashes","status":200,"ts":1541439827796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Kid Cudi \/ Ratatat","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":27,"lastName":"Klein","length":246.72608,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Alive (nightmare)","status":200,"ts":1541439936796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Panic! At The Disco","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Graves","length":215.92771,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"The Only Difference Between Martyrdom and Suicide Is Press Coverage (Tommie Sunshine Brooklyn Fire Remix)","status":200,"ts":1541440023796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Eminem","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":39,"lastName":"Harrell","length":251.55873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Without Me","status":200,"ts":1541440053796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Huey Lewis & The News","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":28,"lastName":"Klein","length":286.4322,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"I Want A New Drug","status":200,"ts":1541440182796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Deana Carter","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Graves","length":214.5171,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"She's Good For You","status":200,"ts":1541440238796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Righteous Brothers","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":40,"lastName":"Harrell","length":168.75057,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Ebb Tide","status":200,"ts":1541440304796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"12 Stones","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":4,"lastName":"Graves","length":200.9073,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"Adrenaline","status":200,"ts":1541440452796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Randy Houser","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":29,"lastName":"Klein","length":171.88526,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Boots On","status":200,"ts":1541440468796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Smiths","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":41,"lastName":"Harrell","length":123.01016,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Girlfriend In A Coma","status":200,"ts":1541440472796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Eagle-Eye Cherry","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":42,"lastName":"Harrell","length":242.78159,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Save Tonight","status":200,"ts":1541440595796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bo Hansson","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":30,"lastName":"Klein","length":240.63955,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Lothlorien (2002 Digital Remaster)","status":200,"ts":1541440639796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Edwyn Collins","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":5,"lastName":"Graves","length":235.91138,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"A Girl Like You","status":200,"ts":1541440652796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Jesper Kyd","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":43,"lastName":"Harrell","length":138.39628,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Ezio In Florence","status":200,"ts":1541440837796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Karen Clark Sheard","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":31,"lastName":"Klein","length":220.81261,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Good","status":200,"ts":1541440879796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Edison Glass","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":6,"lastName":"Graves","length":141.21751,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"Let Go","status":200,"ts":1541440887796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":44,"lastName":"Harrell","length":244.68853,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Life In Technicolor ii","status":200,"ts":1541440975796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Mayday Parade","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":7,"lastName":"Graves","length":241.10975,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"I Swear This Time I Mean It (Album Version)","status":200,"ts":1541441028796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Alejandro Sanz","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":32,"lastName":"Klein","length":266.84036,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Sin que se note","status":200,"ts":1541441099796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":33,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"About","registration":1540558108796.0,"sessionId":255,"song":null,"status":200,"ts":1541441193796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"LMFAO \/ Lil Jon","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":45,"lastName":"Harrell","length":222.17098,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Shots","status":200,"ts":1541441219796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":34,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Home","registration":1540558108796.0,"sessionId":255,"song":null,"status":200,"ts":1541441267796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"New Buffalo","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":8,"lastName":"Graves","length":233.58649,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"I've got you and you've got me - song of contentment","status":200,"ts":1541441269796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The New Pornographers","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":35,"lastName":"Klein","length":272.71791,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Go Places","status":200,"ts":1541441365796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Stavento","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":46,"lastName":"Harrell","length":512.80934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Outro","status":200,"ts":1541441441796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"XTC","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":9,"lastName":"Graves","length":152.89424,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"Into The Atom Age (2001 Digital Remaster)","status":200,"ts":1541441502796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Usher","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":36,"lastName":"Klein","length":224.10404,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Hey Daddy (Daddy's Home)","status":200,"ts":1541441637796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Sia","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":10,"lastName":"Graves","length":253.6224,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"Little Black Sandals","status":200,"ts":1541441654796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Train","auth":"Logged In","firstName":"Carlos","gender":"M","itemInSession":0,"lastName":"Carter","length":216.76363,"level":"free","location":"Miami-Fort Lauderdale-West Palm Beach, FL","method":"PUT","page":"NextSong","registration":1540891212796.0,"sessionId":125,"song":"Hey_ Soul Sister","status":200,"ts":1541441848796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"27"} {"artist":"Kid Cudi \/ MGMT \/ Ratatat","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":37,"lastName":"Klein","length":295.67955,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"Pursuit Of Happiness (nightmare)","status":200,"ts":1541441861796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Smokie Norful","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":11,"lastName":"Graves","length":170.52689,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"Chapter 6: Exercise That Muscle","status":200,"ts":1541441907796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Radiohead","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":47,"lastName":"Harrell","length":261.45914,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Karma Police","status":200,"ts":1541441953796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":12,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Home","registration":1540664184796.0,"sessionId":231,"song":null,"status":200,"ts":1541441977796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Old 97's","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":13,"lastName":"Graves","length":231.28771,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"Victoria (LP Version)","status":200,"ts":1541442077796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The Dust Brothers (featuring Tyler Durden)","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":38,"lastName":"Klein","length":211.12118,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"This Is Your Life (featuring Tyler Durden) (Album Version)","status":200,"ts":1541442156796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Plastilina Mosh","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":48,"lastName":"Harrell","length":261.45914,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":147,"song":"Mr. P-Mosh","status":200,"ts":1541442214796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Tree63","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":14,"lastName":"Graves","length":183.84934,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"The Answer To The Question","status":200,"ts":1541442308796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The Yardbirds","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":39,"lastName":"Klein","length":206.10567,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":255,"song":"The Train Kept A Rollin'","status":200,"ts":1541442367796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Justice","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":15,"lastName":"Graves","length":243.40853,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"TTHHEE PPAARRTTYY","status":200,"ts":1541442491796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":0,"lastName":"Lynch","length":null,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":28,"song":null,"status":200,"ts":1541442528796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Matt Redman","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":16,"lastName":"Graves","length":298.73587,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"This Is How We Know","status":200,"ts":1541442734796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":282,"song":null,"status":200,"ts":1541442759796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"NEEDTOBREATHE","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":209.8673,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":282,"song":"Streets Of Gold (Album Version)","status":200,"ts":1541442773796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Maximilian Hecker","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":1,"lastName":"Lynch","length":295.60118,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":28,"song":"Let Me Out","status":200,"ts":1541442899796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"KALIMBA","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Fox","length":279.87546,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":282,"song":"Tu Coraz\u00c3\u0083\u00c2\u00b3n lo sabe (Lat'n Party)","status":200,"ts":1541442982796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":17,"lastName":"Graves","length":262.24281,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"The Wind Blows","status":200,"ts":1541443032796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"John Prine","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Fox","length":185.96526,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":282,"song":"Aimless Love","status":200,"ts":1541443261796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Dead Prez","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":18,"lastName":"Graves","length":300.17261,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"Hip Hop","status":200,"ts":1541443294796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Girl Talk","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":4,"lastName":"Fox","length":170.73587,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":282,"song":"Hold up","status":200,"ts":1541443446796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Queens Of The Stone Age","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":19,"lastName":"Graves","length":339.90485,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"Misfit Love","status":200,"ts":1541443594796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Miguel Calo","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":5,"lastName":"Fox","length":171.17995,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":282,"song":"El Cuatrero","status":200,"ts":1541443616796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Foals","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":20,"lastName":"Graves","length":368.61342,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"After Glow","status":200,"ts":1541443933796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Alison Krauss","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":21,"lastName":"Graves","length":267.57179,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"I Give You To His Heart","status":200,"ts":1541444301796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":22,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Help","registration":1540664184796.0,"sessionId":231,"song":null,"status":200,"ts":1541444403796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":23,"lastName":"Graves","length":289.90649,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":231,"song":"Shadow Of The Day (Album Version)","status":200,"ts":1541444568796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Vampire Weekend","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":137.82159,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":296,"song":"A-Punk (Album)","status":200,"ts":1541451499796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Crystal","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":251.97669,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":296,"song":"V\u00c3\u0083\u00c2\u0081NDORMAD\u00c3\u0083\u00c2\u0081R","status":200,"ts":1541451636796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Plain White T S","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":266.94485,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":261,"song":"A Lonely September (Album)","status":200,"ts":1541453165796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Eddie Cochran","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Smith","length":113.68444,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":261,"song":"Mean When I'm Mad","status":200,"ts":1541453431796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":null,"auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":0,"lastName":"Rosales","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1541059521796.0,"sessionId":209,"song":null,"status":200,"ts":1541461697796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":1,"lastName":"Rosales","length":214.67383,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541059521796.0,"sessionId":209,"song":"One Time","status":200,"ts":1541461788796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"}
462.960784
649
0.697171
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":null,"auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":0,"lastName":"Barrera","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540835983796.0,"sessionId":248,"song":null,"status":200,"ts":1541470364796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Gustavo Cerati","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":1,"lastName":"Barrera","length":249.44281,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":248,"song":"Uno Entre 1000","status":200,"ts":1541470383796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Limp Bizkit","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":2,"lastName":"Barrera","length":270.49751,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":248,"song":"Behind Blue Eyes","status":200,"ts":1541470632796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":null,"auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540492941796.0,"sessionId":252,"song":null,"status":200,"ts":1541473967796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Mikel Erentxun","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":1,"lastName":"Gonzalez","length":178.83383,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":252,"song":"Frases Mudas","status":200,"ts":1541474048796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"The Gerbils","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":0,"lastName":"Johnson","length":27.01016,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":250,"song":"(iii)","status":200,"ts":1541480171796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"AFI","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":1,"lastName":"Johnson","length":190.45832,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":250,"song":"Girl's Not Grey","status":200,"ts":1541480198796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":null,"auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":null,"level":"free","location":"Salinas, CA","method":"GET","page":"Home","registration":1540008898796.0,"sessionId":240,"song":null,"status":200,"ts":1541480984796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Lhasa De Sela","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":1,"lastName":"Hicks","length":256.10404,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":240,"song":"De cara a la pared","status":200,"ts":1541481077796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"J.J. Cale","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":2,"lastName":"Hicks","length":150.80444,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":240,"song":"Crazy Mama","status":200,"ts":1541481333796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Brian Eno","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":3,"lastName":"Hicks","length":265.82159,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":240,"song":"An Ending (Ascent) (2005 Digital Remaster)","status":200,"ts":1541481483796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Hot Hot Heat","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":4,"lastName":"Hicks","length":190.01424,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":240,"song":"Soldier In A Box (Album Version)","status":200,"ts":1541481748796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":287,"song":null,"status":200,"ts":1541483351796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"ATB","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":209.26649,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":278,"song":"You're Not Alone","status":200,"ts":1541484351796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":null,"level":"free","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":279,"song":null,"status":200,"ts":1541484363796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mt. St. Helens Vietnam Band","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":253.6224,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":278,"song":"A Year Or Two","status":200,"ts":1541484560796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Becky","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":245.62893,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":278,"song":"Kimi e","status":200,"ts":1541484813796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Franz Ferdinand","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":3,"lastName":"Smith","length":254.69342,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":278,"song":"This Fire","status":200,"ts":1541485058796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":4,"lastName":"Smith","length":230.94812,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":278,"song":"It's Just A Thought","status":200,"ts":1541485312796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Paul Stanley","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":187.32363,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":279,"song":"Live To Win","status":200,"ts":1541485351796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Benga","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":314.64444,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":191,"song":"Pleasure","status":200,"ts":1541489492796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Basshunter","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":1,"lastName":"Arellano","length":190.17098,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":191,"song":"Why","status":200,"ts":1541489806796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":2,"lastName":"Arellano","length":231.81016,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":191,"song":"Use Somebody","status":200,"ts":1541489996796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Slim Dusty","auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":0,"lastName":"Rosales","length":198.922,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541059521796.0,"sessionId":300,"song":"Long Black Road","status":200,"ts":1541494159796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":306,"song":null,"status":200,"ts":1541496567796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Dido","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":0,"lastName":"Williams","length":235.57179,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":215,"song":"I'm No Angel","status":200,"ts":1541498691796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Lifehouse","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":1,"lastName":"Williams","length":195.47383,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":215,"song":"You And Me (Wedding Version)","status":200,"ts":1541498926796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Gary U.S. Bonds","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":2,"lastName":"Williams","length":243.25179,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":215,"song":"Angelyne","status":200,"ts":1541499121796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Throw Me The Statue","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":3,"lastName":"Williams","length":189.85751,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":215,"song":"Noises","status":200,"ts":1541499364796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Steely Dan","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":457.89995,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":206,"song":"Deacon Blues","status":200,"ts":1541505185796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":null,"level":"free","location":"New Haven-Milford, CT","method":"GET","page":"Home","registration":1540931983796.0,"sessionId":211,"song":null,"status":200,"ts":1541509101796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":191.26812,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":211,"song":"Old Yellow Bricks","status":200,"ts":1541509129796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Sade","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":2,"lastName":"Robinson","length":271.96036,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":211,"song":"Hang On To Your Love","status":200,"ts":1541509320796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":null,"auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":3,"lastName":"Robinson","length":null,"level":"free","location":"New Haven-Milford, CT","method":"GET","page":"Home","registration":1540931983796.0,"sessionId":211,"song":null,"status":200,"ts":1541509428796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":0,"lastName":"Harris","length":219.66322,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":251,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1541512300796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":0,"lastName":"George","length":null,"level":"free","location":"Birmingham-Hoover, AL","method":"GET","page":"About","registration":1541020249796.0,"sessionId":233,"song":null,"status":200,"ts":1541512431796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":0,"lastName":"Burke","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540676534796.0,"sessionId":230,"song":null,"status":200,"ts":1541514106796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"Vinnie Vincent Invasion","auth":"Logged In","firstName":"Sienna","gender":"F","itemInSession":0,"lastName":"Colon","length":303.12444,"level":"free","location":"Las Cruces, NM","method":"PUT","page":"NextSong","registration":1540013692796.0,"sessionId":291,"song":"Ashes To Ashes (2003 Digital Remaster)","status":200,"ts":1541515050796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"81"} {"artist":null,"auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":0,"lastName":"Ayala","length":null,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"GET","page":"Home","registration":1541007976796.0,"sessionId":33,"song":null,"status":200,"ts":1541515916796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":null,"auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":1,"lastName":"Ayala","length":null,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"GET","page":"Settings","registration":1541007976796.0,"sessionId":33,"song":null,"status":200,"ts":1541516074796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":null,"auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":2,"lastName":"Ayala","length":null,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"GET","page":"Settings","registration":1541007976796.0,"sessionId":33,"song":null,"status":200,"ts":1541516093796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":"Hellogoodbye;Elliott Yamin","auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":3,"lastName":"Ayala","length":218.38322,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"PUT","page":"NextSong","registration":1541007976796.0,"sessionId":33,"song":"Here (In Your Arms) (Radio Edit)","status":200,"ts":1541516147796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":"Kanye West","auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":4,"lastName":"Ayala","length":311.92771,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"PUT","page":"NextSong","registration":1541007976796.0,"sessionId":33,"song":"Stronger","status":200,"ts":1541516365796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":"Interpol","auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":5,"lastName":"Ayala","length":247.66649,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"PUT","page":"NextSong","registration":1541007976796.0,"sessionId":33,"song":"Narc","status":200,"ts":1541516676796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":"Eminem","auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":6,"lastName":"Ayala","length":284.18567,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"PUT","page":"NextSong","registration":1541007976796.0,"sessionId":33,"song":"The Real Slim Shady","status":200,"ts":1541516923796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"GET","page":"Home","registration":1540006905796.0,"sessionId":308,"song":null,"status":200,"ts":1541517250796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":130,"song":null,"status":307,"ts":1541519496796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":1,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1540871783796.0,"sessionId":130,"song":null,"status":200,"ts":1541519519796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Carla Bruni","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":2,"lastName":"Watkins","length":163.02975,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"Quelqu'un M'a Dit (Album Version)","status":200,"ts":1541519555796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Toby Keith","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":3,"lastName":"Watkins","length":192.31302,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"You Ain't Leavin' (Thank God Are Ya)","status":200,"ts":1541519718796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Dim Chris_ Thomas Gold","auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":0,"lastName":"Benjamin","length":504.60689,"level":"free","location":"Plymouth, IN","method":"PUT","page":"NextSong","registration":1539908999796.0,"sessionId":126,"song":"Self Control (Laurent Wolf & Anton Wick)","status":200,"ts":1541519780796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":"Blue Rodeo","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":4,"lastName":"Watkins","length":310.9873,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"Hasn't Hit Me Yet","status":200,"ts":1541519910796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":305,"song":null,"status":200,"ts":1541520058796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Evanescence","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":237.11302,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":305,"song":"Bring Me To Life","status":200,"ts":1541520095796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":5,"lastName":"Watkins","length":190.06649,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"I'd Rather Go Blind","status":200,"ts":1541520220796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Lupe Fiasco","auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":1,"lastName":"Benjamin","length":262.89587,"level":"free","location":"Plymouth, IN","method":"PUT","page":"NextSong","registration":1539908999796.0,"sessionId":126,"song":"Hurt Me Soul (Explicit Album Version)","status":200,"ts":1541520284796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":"Deadmau5","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Burns","length":296.64608,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":305,"song":"Moar Ghosts 'n' Stuff","status":200,"ts":1541520332796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":6,"lastName":"Watkins","length":295.13098,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"Face To Face \/ Short Circuit","status":200,"ts":1541520410796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Jay-Jay Johanson","auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":2,"lastName":"Benjamin","length":381.43955,"level":"free","location":"Plymouth, IN","method":"PUT","page":"NextSong","registration":1539908999796.0,"sessionId":126,"song":"Tell Me When The Party's Over\/Prequiem","status":200,"ts":1541520546796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":"Gigi D'agostino","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Burns","length":241.73669,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":305,"song":"Emotions","status":200,"ts":1541520628796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Great Lake Swimmers","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":7,"lastName":"Watkins","length":185.46893,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"Falling Into the Sky","status":200,"ts":1541520705796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Burns","length":175.38567,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":305,"song":"Lying From You (Album Version)","status":200,"ts":1541520869796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"the bird and the bee","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":8,"lastName":"Watkins","length":225.17506,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"My Love","status":200,"ts":1541520890796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Martine McCutcheon","auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":3,"lastName":"Benjamin","length":185.05098,"level":"free","location":"Plymouth, IN","method":"PUT","page":"NextSong","registration":1539908999796.0,"sessionId":126,"song":"The Lady Is A Tramp (From 'Babes In Arms')","status":200,"ts":1541520927796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":5,"lastName":"Burns","length":191.55546,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":305,"song":"Love Me","status":200,"ts":1541521044796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Leo Garc\u00c3\u0083\u00c2\u00ada","auth":"Logged In","firstName":"Katherine","gender":"F","itemInSession":0,"lastName":"Gay","length":160.91383,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540968306796.0,"sessionId":266,"song":"Nadie Salva","status":200,"ts":1541521083796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_6_8) AppleWebKit\/534.59.10 (KHTML, like Gecko) Version\/5.1.9 Safari\/534.59.10\"","userId":"57"} {"artist":"Matt Redman","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":9,"lastName":"Watkins","length":289.35791,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"You Never Let Go","status":200,"ts":1541521115796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Coldplay","auth":"Logged In","firstName":"Katherine","gender":"F","itemInSession":1,"lastName":"Gay","length":268.38159,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540968306796.0,"sessionId":266,"song":"Yellow","status":200,"ts":1541521243796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_6_8) AppleWebKit\/534.59.10 (KHTML, like Gecko) Version\/5.1.9 Safari\/534.59.10\"","userId":"57"} {"artist":"DHT Feat. Edm\u00c3\u0083\u00c2\u00a9e","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":10,"lastName":"Watkins","length":229.98159,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"Listen To Your Heart","status":200,"ts":1541521404796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Tarkan","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":11,"lastName":"Watkins","length":194.16771,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"Simarik","status":200,"ts":1541521633796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Rifles","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":12,"lastName":"Watkins","length":147.87873,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"For The Meantime","status":200,"ts":1541521827796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":4,"lastName":"Benjamin","length":null,"level":"free","location":"Plymouth, IN","method":"GET","page":"Home","registration":1539908999796.0,"sessionId":126,"song":null,"status":200,"ts":1541521842796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":"The Killers","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":13,"lastName":"Watkins","length":491.57179,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"Human","status":200,"ts":1541521974796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"J. Geils Band","auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":5,"lastName":"Benjamin","length":224.44363,"level":"free","location":"Plymouth, IN","method":"PUT","page":"NextSong","registration":1539908999796.0,"sessionId":126,"song":"Love Stinks","status":200,"ts":1541522071796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":"Shakira","auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":6,"lastName":"Benjamin","length":148.1922,"level":"free","location":"Plymouth, IN","method":"PUT","page":"NextSong","registration":1539908999796.0,"sessionId":126,"song":"Pienso En Ti","status":200,"ts":1541522295796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":null,"auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":7,"lastName":"Benjamin","length":null,"level":"free","location":"Plymouth, IN","method":"PUT","page":"Logout","registration":1539908999796.0,"sessionId":126,"song":null,"status":307,"ts":1541522296796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":8,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":126,"song":null,"status":200,"ts":1541522448796,"userAgent":null,"userId":""} {"artist":"Radiohead","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":14,"lastName":"Watkins","length":231.91465,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"(Nice Dream)","status":200,"ts":1541522465796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":310,"song":null,"status":200,"ts":1541522479796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":9,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"About","registration":null,"sessionId":126,"song":null,"status":200,"ts":1541522507796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":10,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":126,"song":null,"status":307,"ts":1541522508796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":11,"lastName":"Benjamin","length":null,"level":"free","location":"Plymouth, IN","method":"GET","page":"Home","registration":1539908999796.0,"sessionId":126,"song":null,"status":200,"ts":1541522568796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":"Muse","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":15,"lastName":"Watkins","length":304.84853,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":130,"song":"Uprising","status":200,"ts":1541522696796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Spoon","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":222.32771,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":312,"song":"The Underdog (Album version)","status":200,"ts":1541525975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Blind Pilot","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":195.39546,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":312,"song":"Things I Cannot Recall","status":200,"ts":1541526197796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Delirious?","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":397.26975,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":312,"song":"History Maker","status":200,"ts":1541526392796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":3,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Upgrade","registration":1540511766796.0,"sessionId":312,"song":null,"status":200,"ts":1541526425796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Incubus","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":237.06077,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Love Hurts","status":200,"ts":1541527887796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"No Te Va Gustar","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":162.95138,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"No Llegas A M\u00c3\u0083\u00c2\u00ad","status":200,"ts":1541528124796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Radiohead","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":321.27955,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"There_ There","status":200,"ts":1541528286796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Nas","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":268.7473,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Black President","status":200,"ts":1541528607796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Samajona","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":178.36363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Shake Your Body","status":200,"ts":1541528875796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Chicane","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":218.33098,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Love On The Run","status":200,"ts":1541529053796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Lupe Fiasco","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":280.52853,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"American Terrorist [feat. Matthew Santos] (Explicit Album Version)","status":200,"ts":1541529271796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Madonna","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":260.75383,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Beautiful Stranger","status":200,"ts":1541529551796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Telex","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":352.83546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"On The Road Again (Pigna People Remix)","status":200,"ts":1541529811796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":209.52771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Float On","status":200,"ts":1541530163796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Cassandra Wilson","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":283.0624,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":322,"song":"Dust My Broom","status":200,"ts":1541530317796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Eminem \/ Dina Rae","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":350.11873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Superman","status":200,"ts":1541530372796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Eliza Doolittle","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":200.30649,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":322,"song":"Police Car","status":200,"ts":1541530600796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Vivian Green","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":336.43057,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Love For Sale","status":200,"ts":1541530722796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Dean Martin","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":12,"lastName":"Harrell","length":185.83465,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Non Dimenticar","status":200,"ts":1541531058796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Skid Row","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":13,"lastName":"Harrell","length":218.64444,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Swallow Me (The Real You)","status":200,"ts":1541531243796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Destroy The Runner","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":14,"lastName":"Harrell","length":232.09751,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Mr. And Mrs. Cuckoldom","status":200,"ts":1541531461796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":15,"lastName":"Harrell","length":348.57751,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Undo","status":200,"ts":1541531693796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Green Day","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":16,"lastName":"Harrell","length":213.02812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Give Me Novacaine [feat. Green Day & The Cast Of American Idiot] (Album Version)","status":200,"ts":1541532041796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"23 Skidoo","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":17,"lastName":"Harrell","length":236.56444,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"S-Matrix (Part 1 - A Winter Ritual)","status":200,"ts":1541532254796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Thurston Moore","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":18,"lastName":"Harrell","length":139.98975,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Feathers","status":200,"ts":1541532490796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":19,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Downgrade","registration":1540472624796.0,"sessionId":293,"song":null,"status":200,"ts":1541532510796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":20,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":293,"song":null,"status":200,"ts":1541532621796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Irma Thomas","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":21,"lastName":"Harrell","length":180.50567,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Anyone Who Knows What Love Is (Will Understand)","status":200,"ts":1541532629796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Micatone","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":22,"lastName":"Harrell","length":379.68934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Nomad","status":200,"ts":1541532809796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Jonathan Coulton","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":23,"lastName":"Harrell","length":182.7522,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Still Alive","status":200,"ts":1541533188796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Deftones","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":24,"lastName":"Harrell","length":321.98485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"The Chauffeur (Remastered Version)","status":200,"ts":1541533370796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Telepopmusik","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":25,"lastName":"Harrell","length":332.95628,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Love Can Damage Your Health","status":200,"ts":1541533691796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Monsters Of Folk","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":26,"lastName":"Harrell","length":307.01669,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Dear God (Sincerely M.O.F.)","status":200,"ts":1541534023796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":27,"lastName":"Harrell","length":220.00281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Change Your Mind","status":200,"ts":1541534330796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Masta Killa","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":28,"lastName":"Harrell","length":195.70893,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Ringing Bells","status":200,"ts":1541534550796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Adelitas Way","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":29,"lastName":"Harrell","length":192.26077,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Invincible (WWE Superstars Theme Song) (Explicit)","status":200,"ts":1541534745796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Feral Children","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":30,"lastName":"Harrell","length":194.5073,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Saint","status":200,"ts":1541534937796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Fusebox","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":31,"lastName":"Harrell","length":246.04689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"My Everything (Lost In Worship Album Version)","status":200,"ts":1541535131796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"3OH!3","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":32,"lastName":"Harrell","length":205.81832,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"STILLAROUND [BIGMIX] (Bonus Version)","status":200,"ts":1541535377796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Radiohead","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":33,"lastName":"Harrell","length":129.56689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Faust Arp","status":200,"ts":1541535582796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Jaci Velasquez","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":34,"lastName":"Harrell","length":200.95955,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Something (Album Version)","status":200,"ts":1541535711796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Fernando Ubiergo","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":35,"lastName":"Harrell","length":173.7922,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Yo Pienso En Ti","status":200,"ts":1541535911796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Air Supply","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":0,"lastName":"George","length":361.24689,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":315,"song":"It's Never Too Late (Album Version)","status":200,"ts":1541535943796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Death Cab for Cutie","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":36,"lastName":"Harrell","length":229.66812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Cath... (Album Version)","status":200,"ts":1541536084796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Eminem \/ Nate Dogg","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":1,"lastName":"George","length":297.9522,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":315,"song":"'Till I Collapse","status":200,"ts":1541536304796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Philippe Rochard","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":37,"lastName":"Harrell","length":360.51546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Crumpshit","status":200,"ts":1541536313796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Weezer","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":38,"lastName":"Harrell","length":199.94077,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Island In The Sun","status":200,"ts":1541536673796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Nando Reis","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":39,"lastName":"Harrell","length":254.6673,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"A Letra \"A","status":200,"ts":1541536872796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Aborted","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":40,"lastName":"Harrell","length":267.78077,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Skullfuck Crescendo","status":200,"ts":1541537126796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Walter Beasley","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":41,"lastName":"Harrell","length":287.08526,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Killing Me Softly","status":200,"ts":1541537393796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Enigma","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":42,"lastName":"Harrell","length":262.71302,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Knocking On Forbidden Doors","status":200,"ts":1541537680796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Neil Diamond","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":43,"lastName":"Harrell","length":194.40281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Song Sung Blue","status":200,"ts":1541537942796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Deftones","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":44,"lastName":"Harrell","length":307.3824,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"If Only Tonight We Could Sleep (Remastered Version)","status":200,"ts":1541538136796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":45,"lastName":"Harrell","length":284.94322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Double Bass","status":200,"ts":1541538443796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Will Young","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":46,"lastName":"Harrell","length":213.55057,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Leave Right Now","status":200,"ts":1541538727796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":47,"lastName":"Harrell","length":591.96036,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Estranged","status":200,"ts":1541538940796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Harmonia","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":48,"lastName":"Harrell","length":655.77751,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Sehr kosmisch","status":200,"ts":1541539531796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Alanis Morissette","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":49,"lastName":"Harrell","length":236.45995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Ironic (Acoustic Album Version)","status":200,"ts":1541540186796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Mich\u00c3\u0083\u00c2\u00a8le Arnaud","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":50,"lastName":"Harrell","length":105.50812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Chanson Sur Une Seule Note Samba De Uma Nota So","status":200,"ts":1541540422796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Nicola Marchioro","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":51,"lastName":"Harrell","length":201.1424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Lumidee","status":200,"ts":1541540527796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":52,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Help","registration":1540472624796.0,"sessionId":293,"song":null,"status":200,"ts":1541540546796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Pantera","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":53,"lastName":"Harrell","length":346.51383,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Cemetary Gates (LP Version)","status":200,"ts":1541540728796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Godsmack","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":54,"lastName":"Harrell","length":235.93751,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Speak","status":200,"ts":1541541074796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":55,"lastName":"Harrell","length":357.61587,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Clint Eastwood (Explicit)","status":200,"ts":1541541309796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"Palestine, TX","method":"GET","page":"Home","registration":1540685147796.0,"sessionId":91,"song":null,"status":200,"ts":1541541378796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Ray Barretto","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":1,"lastName":"Smith","length":251.79383,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":91,"song":"Indestructible","status":200,"ts":1541541378796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Usher featuring will.i.am","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":2,"lastName":"Smith","length":395.72853,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":91,"song":"OMG","status":200,"ts":1541541629796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Mates of State","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":56,"lastName":"Harrell","length":227.36934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Parachutes (Funeral Song) (LP Version)","status":200,"ts":1541541666796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Angelo D'Onorio","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":57,"lastName":"Harrell","length":399.98649,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Ain't No One Like You","status":200,"ts":1541541893796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Silversun Pickups","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":58,"lastName":"Harrell","length":253.75302,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Panic Switch (UK edit)","status":200,"ts":1541542292796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Blink-182","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":59,"lastName":"Harrell","length":251.81995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Always","status":200,"ts":1541542545796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Hank Penny","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":60,"lastName":"Harrell","length":145.34485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"No Muss No Fuss No Bother","status":200,"ts":1541542796796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Carrie Underwood","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":61,"lastName":"Harrell","length":225.20118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"So Small","status":200,"ts":1541542941796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Black Box","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":62,"lastName":"Harrell","length":312.99873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Fantasy","status":200,"ts":1541543166796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Cloud Cult","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":63,"lastName":"Harrell","length":213.31546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Running With the Wolves","status":200,"ts":1541543478796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Cartola","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":64,"lastName":"Harrell","length":188.65587,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Verde Que Te Quero Rosa","status":200,"ts":1541543691796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":65,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":293,"song":null,"status":200,"ts":1541543762796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Octopus Project","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":66,"lastName":"Harrell","length":422.16444,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"The Way Things Go","status":200,"ts":1541543879796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Peter Tosh","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":67,"lastName":"Harrell","length":267.49342,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Recruiting Soldiers (2002 Digital Remaster)","status":200,"ts":1541544301796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Alter Bridge","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":68,"lastName":"Harrell","length":286.35383,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Down To My Last","status":200,"ts":1541544568796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Two Door Cinema Club","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":69,"lastName":"Harrell","length":207.43791,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Costume Party","status":200,"ts":1541544854796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Ray LaMontagne","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":70,"lastName":"Harrell","length":236.59057,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Trouble (Album Version)","status":200,"ts":1541545061796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Lady GaGa","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":71,"lastName":"Harrell","length":169.87383,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Fashion","status":200,"ts":1541545297796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Colt Ford","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":72,"lastName":"Harrell","length":170.84036,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Huntin' The World","status":200,"ts":1541545466796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Tracy Byrd","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":73,"lastName":"Harrell","length":182.02077,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Watermelon Crawl","status":200,"ts":1541545636796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Brand New","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":74,"lastName":"Harrell","length":386.7424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Noro","status":200,"ts":1541545818796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":75,"lastName":"Harrell","length":160.02567,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Have You Ever Seen The Rain","status":200,"ts":1541546204796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Earth_ Wind & Fire","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":76,"lastName":"Harrell","length":280.47628,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Pure Gold","status":200,"ts":1541546364796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Fleet Foxes","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":208.03873,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":307,"song":"Tiger Mountain Peasant Song","status":200,"ts":1541546584796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"be your own PET","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":77,"lastName":"Harrell","length":66.87302,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Food Fight!","status":200,"ts":1541546644796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Killers","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":78,"lastName":"Harrell","length":220.89098,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"When You Were Young","status":200,"ts":1541546710796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Roy Ayers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":240.90077,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":307,"song":"Searching","status":200,"ts":1541546792796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Rihanna","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":79,"lastName":"Harrell","length":229.04118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Take A Bow","status":200,"ts":1541546930796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Andres Calamaro","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":80,"lastName":"Harrell","length":144.5873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"El Novio Del Olvido","status":200,"ts":1541547159796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Blue States","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":81,"lastName":"Harrell","length":299.2322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Walkabout","status":200,"ts":1541547303796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":82,"lastName":"Harrell","length":161.85424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Act Nice and Gentle","status":200,"ts":1541547602796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Staind","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":83,"lastName":"Harrell","length":291.65669,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Outside (Original LP Version)","status":200,"ts":1541547763796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"James Taylor","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":84,"lastName":"Harrell","length":253.12608,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Sweet Baby James","status":200,"ts":1541548054796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Moby","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":85,"lastName":"Harrell","length":198.60853,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Time's Up (Dust Mix)","status":200,"ts":1541548307796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Girl Talk","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":86,"lastName":"Harrell","length":170.73587,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Hold up","status":200,"ts":1541548505796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Sean Kingston and Justin Bieber","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":87,"lastName":"Harrell","length":201.9522,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Eenie Meenie","status":200,"ts":1541548675796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"}
462.98913
528
0.696075
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Miami Horror","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":88,"lastName":"Harrell","length":250.8273,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Sometimes","status":200,"ts":1541548876796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The White Stripes","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":89,"lastName":"Harrell","length":241.8673,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"My Doorbell (Album Version)","status":200,"ts":1541549126796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Juan Carmona","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":90,"lastName":"Harrell","length":331.44118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Panales de Algodon","status":200,"ts":1541549367796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Alison Krauss \/ Union Station","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":91,"lastName":"Harrell","length":171.04934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Restless","status":200,"ts":1541549698796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bullet For My Valentine","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":92,"lastName":"Harrell","length":235.65016,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Begging For Mercy","status":200,"ts":1541549869796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":93,"lastName":"Harrell","length":348.57751,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Undo","status":200,"ts":1541550104796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kanye West","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":94,"lastName":"Harrell","length":198.47791,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Celebration","status":200,"ts":1541550452796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":231.52281,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":223,"song":"Stronger Than Me","status":200,"ts":1541550480796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"Saosin","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":95,"lastName":"Harrell","length":238.10567,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"You're Not Alone","status":200,"ts":1541550650796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":96,"lastName":"Harrell","length":195.44771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Last Living Souls","status":200,"ts":1541550888796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"World Inferno\/Friendship Society_ The","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":97,"lastName":"Harrell","length":125.83138,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Everybody Comes to Rick's","status":200,"ts":1541551083796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Fall Out Boy","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":98,"lastName":"Harrell","length":172.01587,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Don't You Know Who I Think I Am?","status":200,"ts":1541551208796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Lonnie Gordon","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":99,"lastName":"Harrell","length":181.21098,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Catch You Baby (Steve Pitron & Max Sanna Radio Edit)","status":200,"ts":1541551380796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Crystal Castles","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":100,"lastName":"Harrell","length":213.05424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Not In Love","status":200,"ts":1541551561796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":0,"lastName":"Johnson","length":null,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"GET","page":"Home","registration":1541081807796.0,"sessionId":303,"song":null,"status":200,"ts":1541551647796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"Cage The Elephant","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":101,"lastName":"Harrell","length":175.12444,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Ain't No Rest For The Wicked (Original Version)","status":200,"ts":1541551774796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Rick Ross","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":102,"lastName":"Harrell","length":277.36771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":293,"song":"Luxury Tax","status":200,"ts":1541551949796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":103,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"Logout","registration":1540472624796.0,"sessionId":293,"song":null,"status":307,"ts":1541551950796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":104,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":293,"song":null,"status":200,"ts":1541551950796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":105,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":293,"song":null,"status":200,"ts":1541551975796,"userAgent":null,"userId":""} {"artist":"Lovehatehero","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":0,"lastName":"Summers","length":216.65914,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":181,"song":"Red Dress","status":200,"ts":1541554284796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":1,"lastName":"Summers","length":264.35873,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":181,"song":"Never Let You Go","status":200,"ts":1541554500796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Zero 7","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":2,"lastName":"Summers","length":199.96689,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":181,"song":"You're My Flame [Album Version]","status":200,"ts":1541554764796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Yeah Yeah Yeahs","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":3,"lastName":"Summers","length":220.96934,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":181,"song":"Heads Will Roll","status":200,"ts":1541554963796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"4 Skins","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":4,"lastName":"Summers","length":165.51138,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":181,"song":"Clockwork Skinhead","status":200,"ts":1541555183796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Anne-Lie Ryd\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":0,"lastName":"Scott","length":176.90077,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":8,"song":"S\u00c3\u0083\u00c2\u00a5n't \u00c3\u0083\u00c2\u0084r Livet (You Can Have Her) (2002 Digital Remaster)","status":200,"ts":1541559210796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"The Smiths","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":1,"lastName":"Scott","length":242.9122,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":8,"song":"There Is A Light That Never Goes Out","status":200,"ts":1541559386796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Metallica","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":2,"lastName":"Scott","length":515.21261,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":8,"song":"Master Of Puppets","status":200,"ts":1541559628796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Flight Of The Conchords","auth":"Logged In","firstName":"Kynnedi","gender":"F","itemInSession":0,"lastName":"Sanchez","length":148.55791,"level":"free","location":"Cedar Rapids, IA","method":"PUT","page":"NextSong","registration":1541079034796.0,"sessionId":192,"song":"Too Many Dicks (On The Dance Floor)","status":200,"ts":1541559660796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_8_5) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"89"} {"artist":"In Flames","auth":"Logged In","firstName":"Kynnedi","gender":"F","itemInSession":1,"lastName":"Sanchez","length":255.76444,"level":"free","location":"Cedar Rapids, IA","method":"PUT","page":"NextSong","registration":1541079034796.0,"sessionId":192,"song":"Come Clarity","status":200,"ts":1541559808796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_8_5) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"89"} {"artist":"Juan Carlos Baglietto","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":3,"lastName":"Scott","length":221.80526,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":8,"song":"Cuando","status":200,"ts":1541560143796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Juan Carlos Baglietto","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":4,"lastName":"Scott","length":285.64853,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":8,"song":"Era En Abril","status":200,"ts":1541560364796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":283,"song":null,"status":200,"ts":1541563523796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Saliva","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":252.44689,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":313,"song":"Click Click Boom","status":200,"ts":1541568474796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Soul II Soul","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":239.67302,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":298,"song":"How Long","status":200,"ts":1541568616796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Los Rodriguez","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":205.21751,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":313,"song":"Enganchate Conmigo","status":200,"ts":1541568726796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Twista feat. Kayne West & Jamie Foxx","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":2,"lastName":"Robinson","length":212.55791,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":313,"song":"Slow Jamz (Feat. Kanye West & Jamie Foxx) (Edited Album Version)","status":200,"ts":1541568931796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Slim Cessna's Auto Club","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":3,"lastName":"Robinson","length":333.37424,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":313,"song":"Unto The Day","status":200,"ts":1541569143796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":null,"auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Home","registration":1540266185796.0,"sessionId":286,"song":null,"status":200,"ts":1541571238796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":null,"auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":1,"lastName":"Cruz","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Settings","registration":1540266185796.0,"sessionId":286,"song":null,"status":200,"ts":1541571605796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Philippe Rochard","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Harris","length":360.51546,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":162,"song":"Crumpshit","status":200,"ts":1541572283796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":null,"auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":2,"lastName":"Cruz","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Home","registration":1540266185796.0,"sessionId":286,"song":null,"status":200,"ts":1541572497796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Mike And The Mechanics","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Harris","length":275.12118,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":162,"song":"A Beggar On A Beach Of Gold","status":200,"ts":1541572643796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"No Doubt","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":2,"lastName":"Harris","length":213.31546,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":162,"song":"Hey You","status":200,"ts":1541572918796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"The White Stripes","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":3,"lastName":"Cruz","length":231.81016,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":286,"song":"Seven Nation Army (Album Version)","status":200,"ts":1541572983796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Oscar Peterson","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":3,"lastName":"Harris","length":516.70159,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":162,"song":"Nighttime","status":200,"ts":1541573131796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Jem","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":0,"lastName":"Barrera","length":242.18077,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":301,"song":"Amazing Life","status":200,"ts":1541577266796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Jagged Edge featuring Run of Run DMC","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":1,"lastName":"Barrera","length":248.37179,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":301,"song":"Let's Get Married","status":200,"ts":1541577508796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":null,"level":"free","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":329,"song":null,"status":200,"ts":1541577563796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":152.60689,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":329,"song":"Baby I'm Yours","status":200,"ts":1541578087796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":null,"level":"free","location":"New Haven-Milford, CT","method":"GET","page":"Home","registration":1540931983796.0,"sessionId":338,"song":null,"status":200,"ts":1541583646796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Pixies","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":89.36444,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":338,"song":"Build High","status":200,"ts":1541583683796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"The Roots \/ Jack Davey","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":2,"lastName":"Robinson","length":155.95057,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":338,"song":"Atonement","status":200,"ts":1541583772796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Mike And The Mechanics","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":3,"lastName":"Robinson","length":275.12118,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":338,"song":"A Beggar On A Beach Of Gold","status":200,"ts":1541583927796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Faithless","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":4,"lastName":"Robinson","length":495.3073,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":338,"song":"Music Matters (Mark Knight Dub)","status":200,"ts":1541584202796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":227.13424,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":204,"song":"Be Somebody","status":200,"ts":1541589678796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":null,"auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Home","registration":1540266185796.0,"sessionId":339,"song":null,"status":200,"ts":1541590304796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Vader","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":1,"lastName":"Cruz","length":128.91383,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":339,"song":"Carnal","status":200,"ts":1541590661796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Wu-Tang Clan","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":2,"lastName":"Cruz","length":122.46159,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":339,"song":"Impossible","status":200,"ts":1541590789796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":326,"song":null,"status":200,"ts":1541591952796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"GET","page":"Home","registration":1540006905796.0,"sessionId":319,"song":null,"status":200,"ts":1541592346796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Matt Nathanson","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":1,"lastName":"Arellano","length":187.03628,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":319,"song":"Bare","status":200,"ts":1541592383796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":2,"lastName":"Arellano","length":194.76853,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":319,"song":"Smile","status":200,"ts":1541592570796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":337,"song":null,"status":200,"ts":1541595680796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":221,"song":null,"status":200,"ts":1541596856796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Harmonia","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":655.77751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":285,"song":"Sehr kosmisch","status":200,"ts":1541596896796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Avril Lavigne","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Koch","length":239.90812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Keep Holding On","status":200,"ts":1541596931796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":320,"song":null,"status":200,"ts":1541597130796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"White Lion","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Koch","length":378.93179,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"When The Children Cry","status":200,"ts":1541597170796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Lifehouse","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Koch","length":195.47383,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"You And Me (Wedding Version)","status":200,"ts":1541597548796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Entombed","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":237.73995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":285,"song":"Stranger Aeons","status":200,"ts":1541597551796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Miley Cyrus","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Koch","length":236.85179,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"The Climb","status":200,"ts":1541597743796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Ray Barretto","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":251.79383,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":285,"song":"Indestructible","status":200,"ts":1541597788796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Syd Barrett","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":5,"lastName":"Koch","length":332.32934,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Lanky (Part One)","status":200,"ts":1541597979796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Thievery Corporation","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":3,"lastName":"Kirby","length":225.85424,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":285,"song":"Racing East","status":200,"ts":1541598039796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":4,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":285,"song":null,"status":200,"ts":1541598052796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":5,"lastName":"Kirby","length":210.85995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":285,"song":"Angel","status":200,"ts":1541598264796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Todd Barry","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":6,"lastName":"Koch","length":126.82404,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Sugar Ray (LP Version)","status":200,"ts":1541598311796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Eddie Vedder","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":7,"lastName":"Koch","length":164.17914,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Guaranteed","status":200,"ts":1541598437796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Arcade Fire","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":6,"lastName":"Kirby","length":343.69261,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":285,"song":"No Cars Go","status":200,"ts":1541598474796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Cartola","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":8,"lastName":"Koch","length":188.65587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Verde Que Te Quero Rosa","status":200,"ts":1541598601796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":177,"song":null,"status":307,"ts":1541598781796,"userAgent":null,"userId":""} {"artist":"India.Arie","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":9,"lastName":"Koch","length":212.13995,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Good Man","status":200,"ts":1541598789796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Avril Lavigne","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":7,"lastName":"Kirby","length":212.40118,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":285,"song":"Tomorrow","status":200,"ts":1541598817796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Morris","gender":"M","itemInSession":1,"lastName":"Gilmore","length":null,"level":"free","location":"Raleigh, NC","method":"GET","page":"Home","registration":1540971561796.0,"sessionId":177,"song":null,"status":200,"ts":1541598853796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_1 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D201 Safari\/9537.53\"","userId":"23"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Morris","gender":"M","itemInSession":2,"lastName":"Gilmore","length":239.3073,"level":"free","location":"Raleigh, NC","method":"PUT","page":"NextSong","registration":1540971561796.0,"sessionId":177,"song":"You're The One","status":200,"ts":1541598892796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_1 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D201 Safari\/9537.53\"","userId":"23"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":10,"lastName":"Koch","length":261.74649,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Halo","status":200,"ts":1541599001796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Franz Ferdinand","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":11,"lastName":"Koch","length":247.24853,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Take Me Out","status":200,"ts":1541599262796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Leggo Beast","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":12,"lastName":"Koch","length":321.93261,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Itchy Feet","status":200,"ts":1541599509796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":13,"lastName":"Koch","length":369.34485,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Aerodynamic (Daft Punk Remix)","status":200,"ts":1541599830796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Interpol","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":14,"lastName":"Koch","length":247.66649,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Narc","status":200,"ts":1541600199796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Sl2","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":15,"lastName":"Koch","length":329.89995,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"On A Ragga Tip","status":200,"ts":1541600446796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Newsboys","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":0,"lastName":"Lynch","length":381.67465,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":295,"song":"It Is You - Live","status":200,"ts":1541600606796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Montgomery Gentry","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":16,"lastName":"Koch","length":202.50077,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"While You're Still Young","status":200,"ts":1541600775796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Shakira","gender":"F","itemInSession":0,"lastName":"Hunt","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Home","registration":1540636000796.0,"sessionId":277,"song":null,"status":200,"ts":1541600976796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"84"} {"artist":"10cc","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":17,"lastName":"Koch","length":300.40771,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Hotel","status":200,"ts":1541600977796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Booka Shade","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":1,"lastName":"Lynch","length":369.97179,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":295,"song":"shimmer","status":200,"ts":1541600987796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Metallica","auth":"Logged In","firstName":"Shakira","gender":"F","itemInSession":1,"lastName":"Hunt","length":515.21261,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540636000796.0,"sessionId":277,"song":"Master Of Puppets","status":200,"ts":1541601035796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"84"} {"artist":"B.o.B","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":18,"lastName":"Koch","length":269.63546,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Nothin' On You [feat. Bruno Mars] (Album Version)","status":200,"ts":1541601277796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"John Mayer","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":2,"lastName":"Lynch","length":267.38893,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":295,"song":"Why Georgia","status":200,"ts":1541601356796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Specials","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":19,"lastName":"Koch","length":218.06975,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Ghost Town","status":200,"ts":1541601546796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Ol' Dirty Bastard","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":20,"lastName":"Koch","length":217.49506,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Brooklyn Zoo [Explicit Version]","status":200,"ts":1541601764796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":21,"lastName":"Koch","length":236.72118,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Bubble Toes","status":200,"ts":1541601981796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Radiohead","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":22,"lastName":"Koch","length":208.61342,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"You","status":200,"ts":1541602217796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Fall Out Boy","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":23,"lastName":"Koch","length":202.37016,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Nobody Puts Baby In The Corner","status":200,"ts":1541602425796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":24,"lastName":"Koch","length":201.1424,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Not Fair (Clean Radio Edit)","status":200,"ts":1541602627796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Polyphonic Spree","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":25,"lastName":"Koch","length":2190.94159,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Section Ten","status":200,"ts":1541602828796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":0,"lastName":"Benjamin","length":null,"level":"free","location":"Plymouth, IN","method":"GET","page":"Home","registration":1539908999796.0,"sessionId":323,"song":null,"status":200,"ts":1541603610796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":"Los Del Rio","auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":1,"lastName":"Benjamin","length":249.49506,"level":"free","location":"Plymouth, IN","method":"PUT","page":"NextSong","registration":1539908999796.0,"sessionId":323,"song":"Macarena","status":200,"ts":1541603777796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":332,"song":null,"status":200,"ts":1541604823796,"userAgent":null,"userId":""} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":26,"lastName":"Koch","length":252.21179,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1541605018796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Shinedown","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":220.39465,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":346,"song":"Second Chance (Album Version)","status":200,"ts":1541605080796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":27,"lastName":"Koch","length":189.28281,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Given Up (Album Version)","status":200,"ts":1541605270796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Poisonblack","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":28,"lastName":"Koch","length":234.78812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Nothing Else ReMayns","status":200,"ts":1541605459796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Radio Dept.","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":29,"lastName":"Koch","length":241.76281,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Your Father","status":200,"ts":1541605693796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Gwen Stefani \/ Andre 3000","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":30,"lastName":"Koch","length":274.02404,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Long Way To Go","status":200,"ts":1541605934796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Shinedown","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":31,"lastName":"Koch","length":253.59628,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"The Crow & The Butterfly (Album Version)","status":200,"ts":1541606208796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Sunnyland Slim","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":32,"lastName":"Koch","length":233.97832,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Slim's Shout","status":200,"ts":1541606461796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":33,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":221,"song":null,"status":200,"ts":1541606628796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Lou Bega","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":34,"lastName":"Koch","length":220.13342,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Mambo No. 5 (A Little Bit Of...)","status":200,"ts":1541606694796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Nevermore","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":35,"lastName":"Koch","length":320.57424,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Matricide","status":200,"ts":1541606914796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Radiohead","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":36,"lastName":"Koch","length":323.5522,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"There_ There","status":200,"ts":1541607234796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Band Of Horses","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":37,"lastName":"Koch","length":256.522,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Ode to LRC (Album)","status":200,"ts":1541607557796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Evanescence","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":38,"lastName":"Koch","length":263.78404,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"My Immortal (Album Version)","status":200,"ts":1541607813796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Eminem","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":39,"lastName":"Koch","length":250.8273,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Mockingbird","status":200,"ts":1541608076796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Chi-Lites","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":40,"lastName":"Koch","length":256.83546,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"A Letter To Myself","status":200,"ts":1541608326796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Hombres G","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":41,"lastName":"Koch","length":131.52608,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Multiplicados por nueve","status":200,"ts":1541608582796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Jazzanova \/ Ben Westbeech","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":42,"lastName":"Koch","length":210.83383,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"I Can See","status":200,"ts":1541608713796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Pleasure P","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":43,"lastName":"Koch","length":211.56526,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Let Me (Amended Album Version)","status":200,"ts":1541608923796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"MGMT","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":44,"lastName":"Koch","length":264.17587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Time To Pretend","status":200,"ts":1541609134796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Kaoma","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":45,"lastName":"Koch","length":206.57587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Lambada","status":200,"ts":1541609398796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Buena Vista Social Club","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":46,"lastName":"Koch","length":221.90975,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Chan Chan (Live)","status":200,"ts":1541609604796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bullet For My Valentine","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":47,"lastName":"Koch","length":348.39465,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Tears Don't Fall","status":200,"ts":1541609825796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Pygmy Lush","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":48,"lastName":"Koch","length":143.28118,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Red Room Blues","status":200,"ts":1541610173796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Jordyn","gender":"F","itemInSession":0,"lastName":"Powell","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Home","registration":1540828399796.0,"sessionId":97,"song":null,"status":200,"ts":1541610288796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"98"} {"artist":"Flight Of The Conchords","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":49,"lastName":"Koch","length":21.68118,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Au Revoir (Album Version)","status":200,"ts":1541610316796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Angels and Airwaves","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":50,"lastName":"Koch","length":302.05342,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"The Gift","status":200,"ts":1541610337796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Blues Brothers","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":51,"lastName":"Koch","length":162.32444,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"(I Got Everything I Need) Almost (Live Version)","status":200,"ts":1541610639796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":52,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":221,"song":null,"status":200,"ts":1541610648796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Carlos Santana & Mahavishnu John McLaughlin","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":53,"lastName":"Koch","length":466.28526,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"A Love Supreme","status":200,"ts":1541610801796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Enya","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":54,"lastName":"Koch","length":180.16608,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"White Is In The Winter Night (Album)","status":200,"ts":1541611267796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":55,"lastName":"Koch","length":185.46893,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Cover Me","status":200,"ts":1541611447796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":56,"lastName":"Koch","length":433.52771,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Hong Kong","status":200,"ts":1541611632796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Nana Caymmi","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":57,"lastName":"Koch","length":174.41914,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Fim De Caso","status":200,"ts":1541612065796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Courteeners","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":58,"lastName":"Koch","length":225.48853,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Take Over The World","status":200,"ts":1541612239796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Blues Brothers","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":59,"lastName":"Koch","length":175.80363,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Messin' With The Kid (Live Version)","status":200,"ts":1541612464796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"William Orbit","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":60,"lastName":"Koch","length":317.962,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Barber's Adagio For Strings (Ferry Corsten Remix)","status":200,"ts":1541612639796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Coldplay","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":61,"lastName":"Koch","length":244.68853,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Life In Technicolor ii","status":200,"ts":1541612956796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Boards of Canada","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":62,"lastName":"Koch","length":229.82485,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"84 Pontiac Dream","status":200,"ts":1541613200796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Tom Waits","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":63,"lastName":"Koch","length":223.26812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Sea Of Love","status":200,"ts":1541613429796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Philippe Rochard","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":64,"lastName":"Koch","length":360.51546,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Crumpshit","status":200,"ts":1541613652796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Dream Academy","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":65,"lastName":"Koch","length":259.29098,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Life In A Northern Town (LP Version)","status":200,"ts":1541614012796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Pantera","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":66,"lastName":"Koch","length":244.50567,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Planet Caravan (Remastered LP Version)","status":200,"ts":1541614271796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"John Miles","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":67,"lastName":"Koch","length":351.9473,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Music","status":200,"ts":1541614515796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Fastway","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":68,"lastName":"Koch","length":259.7873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Don't Stop The Fight","status":200,"ts":1541614866796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":69,"lastName":"Koch","length":249.99138,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Everlong","status":200,"ts":1541615125796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Sascha Funke","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":70,"lastName":"Koch","length":298.97098,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Quiet Please","status":200,"ts":1541615374796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Apsci","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":71,"lastName":"Koch","length":153.25995,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Never Give Up","status":200,"ts":1541615672796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Electric Light Orchestra","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":0,"lastName":"Harris","length":301.94893,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":314,"song":"Mr Blue Sky","status":200,"ts":1541615804796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Cute Is What We Aim For","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":72,"lastName":"Koch","length":171.28444,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Miss Sobriety (Album Version)","status":200,"ts":1541615825796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Andy Starr","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":73,"lastName":"Koch","length":170.86649,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Rockin' Rollin' Stone","status":200,"ts":1541615996796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Underworld","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":1,"lastName":"Harris","length":329.53424,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":314,"song":"Teardrop","status":200,"ts":1541616105796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"The Coral","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":74,"lastName":"Koch","length":211.93098,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Liezah","status":200,"ts":1541616166796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Jadakiss","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":75,"lastName":"Koch","length":189.67465,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Pain & Torture","status":200,"ts":1541616377796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Chet Baker","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":76,"lastName":"Koch","length":264.4371,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Life","status":200,"ts":1541616566796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Alex Ubago","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":77,"lastName":"Koch","length":249.36444,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Que pides tu?","status":200,"ts":1541616830796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":78,"lastName":"Koch","length":1400.2673,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"240 Years Before Your Time","status":200,"ts":1541617079796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Camila","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":252.29016,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":299,"song":"Besame","status":200,"ts":1541617642796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Ill Ni\u00c3\u0083\u00c2\u00b1o","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":79,"lastName":"Koch","length":246.22975,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Numb","status":200,"ts":1541618479796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Billy Currington","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":80,"lastName":"Koch","length":197.66812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Ain't What It Used To Be","status":200,"ts":1541618725796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Killers","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":81,"lastName":"Koch","length":230.03383,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Move Away","status":200,"ts":1541618922796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Wordsworth","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":82,"lastName":"Koch","length":253.1522,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Right Now (Produced by Ayatollah)","status":200,"ts":1541619152796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Shinedown","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":83,"lastName":"Koch","length":220.39465,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Second Chance (Album Version)","status":200,"ts":1541619405796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Ane Brun","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":84,"lastName":"Koch","length":248.37179,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Laid In Earth","status":200,"ts":1541619625796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Chris Kenner","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":85,"lastName":"Koch","length":238.49751,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"I Like It Like That","status":200,"ts":1541619873796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Black Stone Cherry","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":86,"lastName":"Koch","length":266.65751,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"The Key (Album Version)","status":200,"ts":1541620111796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Foolish Things","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":87,"lastName":"Koch","length":266.86649,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Who Can Compare","status":200,"ts":1541620377796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Toto La Momposina","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":88,"lastName":"Koch","length":239.90812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Dame La Mano Juancho","status":200,"ts":1541620643796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Runaways","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":89,"lastName":"Koch","length":201.16853,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"I Love Playin' With Fire","status":200,"ts":1541620882796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Gala","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":90,"lastName":"Koch","length":235.44118,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Suddenly","status":200,"ts":1541621083796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Orishas","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":91,"lastName":"Koch","length":266.39628,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"El Kilo","status":200,"ts":1541621318796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Queen","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":78.47138,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":343,"song":"Nevermore (1994 Digital Remaster)","status":200,"ts":1541621346796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Sondre Lerche","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":171.59791,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":343,"song":"Heartbeat Radio","status":200,"ts":1541621424796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Three Drives","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":92,"lastName":"Koch","length":411.6371,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Greece 2000","status":200,"ts":1541621584796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":93,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Settings","registration":1541048010796.0,"sessionId":221,"song":null,"status":200,"ts":1541621664796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Ottmar Liebert","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":94,"lastName":"Koch","length":174.54975,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Festival (Of 7 Lights)","status":200,"ts":1541621995796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Sondre Lerche","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":95,"lastName":"Koch","length":247.19628,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Don't Be Shallow","status":200,"ts":1541622169796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Robyn Hitchcock and The Egyptians","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":96,"lastName":"Koch","length":214.22975,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"The Black Crow Knows","status":200,"ts":1541622416796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Buggles","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":97,"lastName":"Koch","length":198.08608,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Video Killed The Radio Star","status":200,"ts":1541622630796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":355,"song":null,"status":200,"ts":1541622682796,"userAgent":null,"userId":""} {"artist":"Kid Cudi \/ MGMT \/ Ratatat","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":98,"lastName":"Koch","length":295.67955,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Pursuit Of Happiness (nightmare)","status":200,"ts":1541622828796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Damian Marley \/ Nas","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":99,"lastName":"Koch","length":317.30893,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Road To Zion","status":200,"ts":1541623123796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":100,"lastName":"Koch","length":191.45098,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Pushing Me Away (Album Version)","status":200,"ts":1541623440796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Way Out West","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":101,"lastName":"Koch","length":657.73669,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Killa","status":200,"ts":1541623631796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Mr. Airplane Man","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":102,"lastName":"Koch","length":218.30485,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Lonesome Road","status":200,"ts":1541624288796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Asking Alexandria","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":103,"lastName":"Koch","length":248.99873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"Hey There Mr. Brooks (feat. Feat. Shawn Mike of Alesana)","status":200,"ts":1541624506796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Cat Empire","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":104,"lastName":"Koch","length":307.46077,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":221,"song":"The Chariot","status":200,"ts":1541624754796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":349,"song":null,"status":200,"ts":1541629595796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"STRATOVARIUS","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":350.74567,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":349,"song":"Twilight Time","status":200,"ts":1541629614796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"The Mantles","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Burns","length":226.53342,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":349,"song":"Don't Lie","status":200,"ts":1541629964796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":0,"lastName":"Cook","length":233.69098,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":213,"song":"Invalid","status":200,"ts":1541632356796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":1,"lastName":"Cook","length":173.42649,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":213,"song":"Wrong Turn","status":200,"ts":1541632589796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"}
481.772277
552
0.698787
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":null,"auth":"Logged In","firstName":"Dominick","gender":"M","itemInSession":0,"lastName":"Norris","length":null,"level":"free","location":"Los Angeles-Long Beach-Anaheim, CA","method":"GET","page":"Home","registration":1540975502796.0,"sessionId":44,"song":null,"status":200,"ts":1541635950796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"45"} {"artist":"Slipknot","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Ramirez","length":192.57424,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540283578796.0,"sessionId":19,"song":"Opium Of The People (Album Version)","status":200,"ts":1541639510796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"20"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Ramirez","length":170.57914,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540283578796.0,"sessionId":19,"song":"Don't Be Shy","status":200,"ts":1541639702796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"20"} {"artist":"Collective Soul","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":2,"lastName":"Ramirez","length":273.47546,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540283578796.0,"sessionId":19,"song":"Run (LP Version)","status":200,"ts":1541639872796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"20"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":3,"lastName":"Ramirez","length":233.89995,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540283578796.0,"sessionId":19,"song":"Love Story","status":200,"ts":1541640145796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"20"} {"artist":"The Dixie Cups","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":4,"lastName":"Ramirez","length":120.05832,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540283578796.0,"sessionId":19,"song":"Iko Iko","status":200,"ts":1541640378796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"20"} {"artist":"Carlos Santana & Mahavishnu John McLaughlin","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":5,"lastName":"Ramirez","length":157.93587,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540283578796.0,"sessionId":19,"song":"Meditation","status":200,"ts":1541640498796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"20"} {"artist":"Pixies","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":6,"lastName":"Ramirez","length":280.00608,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540283578796.0,"sessionId":19,"song":"Into The White","status":200,"ts":1541640655796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"20"} {"artist":"Antimatter","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":7,"lastName":"Ramirez","length":245.52444,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540283578796.0,"sessionId":19,"song":"Lights Out","status":200,"ts":1541640935796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"20"} {"artist":null,"auth":"Logged In","firstName":"Christian","gender":"F","itemInSession":0,"lastName":"Porter","length":null,"level":"free","location":"Elkhart-Goshen, IN","method":"GET","page":"Home","registration":1540897318796.0,"sessionId":10,"song":null,"status":200,"ts":1541641041796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"11"} {"artist":"Rihanna","auth":"Logged In","firstName":"Christian","gender":"F","itemInSession":1,"lastName":"Porter","length":293.82485,"level":"free","location":"Elkhart-Goshen, IN","method":"PUT","page":"NextSong","registration":1540897318796.0,"sessionId":10,"song":"Rehab","status":200,"ts":1541641099796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"11"} {"artist":null,"auth":"Logged In","firstName":"Christian","gender":"F","itemInSession":2,"lastName":"Porter","length":null,"level":"free","location":"Elkhart-Goshen, IN","method":"GET","page":"Upgrade","registration":1540897318796.0,"sessionId":10,"song":null,"status":200,"ts":1541641113796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"11"} {"artist":"Soda Stereo","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":8,"lastName":"Ramirez","length":186.69669,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540283578796.0,"sessionId":19,"song":"Observ\u00c3\u0083\u00c2\u00a1ndonos (Sat\u00c3\u0083\u00c2\u00a9lites)","status":200,"ts":1541641180796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"20"} {"artist":null,"auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":9,"lastName":"Ramirez","length":null,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"Logout","registration":1540283578796.0,"sessionId":19,"song":null,"status":307,"ts":1541641181796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"20"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":10,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":19,"song":null,"status":200,"ts":1541641248796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":149,"song":null,"status":307,"ts":1541641946796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":1,"lastName":"Young","length":null,"level":"free","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":149,"song":null,"status":200,"ts":1541641965796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":2,"lastName":"Young","length":null,"level":"free","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":149,"song":null,"status":200,"ts":1541641979796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Jahiem","gender":"M","itemInSession":0,"lastName":"Miles","length":null,"level":"free","location":"San Antonio-New Braunfels, TX","method":"GET","page":"Home","registration":1540817347796.0,"sessionId":265,"song":null,"status":200,"ts":1541648843796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"43"} {"artist":"Metallica","auth":"Logged In","firstName":"Jahiem","gender":"M","itemInSession":1,"lastName":"Miles","length":387.02975,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540817347796.0,"sessionId":265,"song":"Welcome Home (Sanitarium)","status":200,"ts":1541648892796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"43"} {"artist":"Adam Lambert","auth":"Logged In","firstName":"Jahiem","gender":"M","itemInSession":2,"lastName":"Miles","length":227.39546,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540817347796.0,"sessionId":265,"song":"Whataya Want From Me","status":200,"ts":1541649279796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"43"} {"artist":"Beirut","auth":"Logged In","firstName":"Jahiem","gender":"M","itemInSession":3,"lastName":"Miles","length":185.28608,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540817347796.0,"sessionId":265,"song":"The Flying Club Cup","status":200,"ts":1541649506796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"43"} {"artist":"Russell Malone","auth":"Logged In","firstName":"Jahiem","gender":"M","itemInSession":4,"lastName":"Miles","length":396.40771,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540817347796.0,"sessionId":265,"song":"Heartstrings","status":200,"ts":1541649691796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"43"} {"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"GET","page":"Home","registration":1540006905796.0,"sessionId":347,"song":null,"status":200,"ts":1541655005796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":null,"auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":0,"lastName":"Rosales","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1541059521796.0,"sessionId":309,"song":null,"status":200,"ts":1541656906796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":0,"lastName":"Lynch","length":null,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":353,"song":null,"status":200,"ts":1541658138796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Yung Joc feat Jazze Pha","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":1,"lastName":"Lynch","length":233.19465,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":353,"song":"Momma (featuring Jazze Pha) (Amended Album Version)","status":200,"ts":1541658199796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":2,"lastName":"Lynch","length":null,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Upgrade","registration":1540223723796.0,"sessionId":353,"song":null,"status":200,"ts":1541658258796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":3,"lastName":"Lynch","length":null,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"Submit Upgrade","registration":1540223723796.0,"sessionId":353,"song":null,"status":307,"ts":1541658259796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":4,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":353,"song":null,"status":200,"ts":1541658357796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Metallica","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":5,"lastName":"Lynch","length":515.21261,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":353,"song":"Master Of Puppets","status":200,"ts":1541658432796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":6,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Settings","registration":1540223723796.0,"sessionId":353,"song":null,"status":200,"ts":1541658652796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":7,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"Logout","registration":1540223723796.0,"sessionId":353,"song":null,"status":307,"ts":1541658653796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":8,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":353,"song":null,"status":200,"ts":1541658827796,"userAgent":null,"userId":""} {"artist":"Pavement","auth":"Logged In","firstName":"Marina","gender":"F","itemInSession":0,"lastName":"Sutton","length":99.16036,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1541064343796.0,"sessionId":188,"song":"Mercy:The Laundromat","status":200,"ts":1541660400796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"48"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":null,"level":"free","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":342,"song":null,"status":200,"ts":1541661182796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Andre Hazes","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":195.36934,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Che Sara","status":200,"ts":1541661323796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":null,"level":"free","location":"Portland-South Portland, ME","method":"GET","page":"Upgrade","registration":1540794356796.0,"sessionId":342,"song":null,"status":200,"ts":1541661398796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":null,"level":"free","location":"Portland-South Portland, ME","method":"PUT","page":"Submit Upgrade","registration":1540794356796.0,"sessionId":342,"song":null,"status":307,"ts":1541661399796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":342,"song":null,"status":200,"ts":1541661495796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Joan Baez","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":215.14404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Let It Be","status":200,"ts":1541661518796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Porcupine Tree","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":217.39057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Hallogallo","status":200,"ts":1541661733796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":342,"song":null,"status":200,"ts":1541662356796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":361,"song":null,"status":200,"ts":1541662462796,"userAgent":null,"userId":""} {"artist":"Coldplay","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":228.77995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"In My Place","status":200,"ts":1541662640796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Usher","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":224.10404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Hey Daddy (Daddy's Home)","status":200,"ts":1541662868796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Fabolous","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":222.9024,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Can't Let You Go featuring Mike Shorey & Lil' Mo (Main LP Version)","status":200,"ts":1541663092796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Sheena Easton","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":239.62077,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Strut (1993 Digital Remaster)","status":200,"ts":1541663314796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Restiform Bodies","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":229.14567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Interactive Halloween Bear","status":200,"ts":1541663553796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Settings","registration":1540794356796.0,"sessionId":342,"song":null,"status":200,"ts":1541663573796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Killers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":284.60363,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Spaceman","status":200,"ts":1541663782796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kaiser Chiefs","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":217.62567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Everyday I Love You Less and Less","status":200,"ts":1541664066796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Downgrade","registration":1540794356796.0,"sessionId":342,"song":null,"status":200,"ts":1541664412796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Delerium","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":275.01669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Till The End Of Time","status":200,"ts":1541665227796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Christophe Ma\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":18,"lastName":"Levine","length":237.47873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"La Rumeur","status":200,"ts":1541665502796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"F.I.R.","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":19,"lastName":"Levine","length":283.6371,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Ni Hen Ai Ta","status":200,"ts":1541665739796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Pearl Jam","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":20,"lastName":"Levine","length":268.7473,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Better Man","status":200,"ts":1541666022796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Fey","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":0,"lastName":"White","length":266.86649,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":258,"song":"Como Un \u00c3\u0083\u00c2\u0081ngel","status":200,"ts":1541666173796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Delerium feat. Sarah McLachlan","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":21,"lastName":"Levine","length":494.81098,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Silence","status":200,"ts":1541666290796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Newton Faulkner","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":1,"lastName":"White","length":177.3971,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":258,"song":"I Need Something","status":200,"ts":1541666439796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Justice","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":22,"lastName":"Levine","length":265.16853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Waters Of Nazareth (album version)","status":200,"ts":1541666784796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Muse","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":23,"lastName":"Levine","length":209.34485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Supermassive Black Hole (Album Version)","status":200,"ts":1541667049796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bebo & Cigala","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":24,"lastName":"Levine","length":175.90812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Vete De Mi","status":200,"ts":1541667258796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Almost","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":25,"lastName":"Levine","length":222.24934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Dirty And Left Out","status":200,"ts":1541667433796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":26,"lastName":"Levine","length":374.59546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Get Me Bodied","status":200,"ts":1541667655796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Base Ball Bear","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":27,"lastName":"Levine","length":255.60771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Sayonara-Nostalgia","status":200,"ts":1541668029796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Badly Drawn Boy","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":28,"lastName":"Levine","length":247.97995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"This Is That New Song","status":200,"ts":1541668284796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Alicia Keys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":29,"lastName":"Levine","length":249.02485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Try Sleeping With A Broken Heart","status":200,"ts":1541668531796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":30,"lastName":"Levine","length":208.01261,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Girl Is On My Mind","status":200,"ts":1541668780796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Juanes","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":31,"lastName":"Levine","length":205.73995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"A Dios Le Pido","status":200,"ts":1541668988796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"John Mayer","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":32,"lastName":"Levine","length":149.39383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Crossroads","status":200,"ts":1541669193796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The xx","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":33,"lastName":"Levine","length":188.55138,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Basic Space","status":200,"ts":1541669342796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Killers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":34,"lastName":"Levine","length":220.89098,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"When You Were Young","status":200,"ts":1541669530796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Prodigy","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":35,"lastName":"Levine","length":260.07465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"The Big Gundown","status":200,"ts":1541669750796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Machine Head","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":36,"lastName":"Levine","length":333.13914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"A Nation On Fire (Album Version)","status":200,"ts":1541670010796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Coldplay","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":37,"lastName":"Levine","length":291.60444,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Speed Of Sound","status":200,"ts":1541670343796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":38,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":342,"song":null,"status":200,"ts":1541671130796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Michael Jackson","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":39,"lastName":"Levine","length":373.73342,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Little Susie \/ Pie Jesu","status":200,"ts":1541671259796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Daddy Yankee","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":40,"lastName":"Levine","length":235.15383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"A Lo Clasico","status":200,"ts":1541671632796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Flobots","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":41,"lastName":"Levine","length":307.56526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Never Had It","status":200,"ts":1541671867796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Quantic","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":42,"lastName":"Levine","length":275.01669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"When You're Through Feat. Spanky Wilson","status":200,"ts":1541672174796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"New Order","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":43,"lastName":"Levine","length":261.72036,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Love Vigilantes","status":200,"ts":1541672449796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Cold","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":44,"lastName":"Levine","length":197.27628,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"No One","status":200,"ts":1541672710796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Counting Crows","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":45,"lastName":"Levine","length":272.79628,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Mr. Jones","status":200,"ts":1541672907796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"DEATH","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":46,"lastName":"Levine","length":376.81587,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Symbolic","status":200,"ts":1541673179796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":0,"lastName":"Brock","length":null,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"GET","page":"Home","registration":1540852600796.0,"sessionId":117,"song":null,"status":200,"ts":1541673267796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Vangelis","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":1,"lastName":"Brock","length":352.78322,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"La Petite Fille De La Mer","status":200,"ts":1541673271796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Armin van Buuren","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":47,"lastName":"Levine","length":452.23138,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Never Say Never","status":200,"ts":1541673555796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":2,"lastName":"Brock","length":222.92853,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Stuck In The Moment","status":200,"ts":1541673623796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Sleep","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":3,"lastName":"Brock","length":426.84036,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Evil Gypsy - Solomons Theme","status":200,"ts":1541673845796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Lady GaGa \/ Colby O'Donis","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":48,"lastName":"Levine","length":238.54975,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Just Dance","status":200,"ts":1541674007796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":49,"lastName":"Levine","length":201.79546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Revelry","status":200,"ts":1541674245796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Leon Gieco","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":4,"lastName":"Brock","length":285.02159,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"La Colina De La Vida","status":200,"ts":1541674271796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"U2","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":50,"lastName":"Levine","length":190.98077,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Vertigo","status":200,"ts":1541674446796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"George Jones and Gene Pitney","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":5,"lastName":"Brock","length":166.3473,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Wreck On the Highway","status":200,"ts":1541674556796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Kanye West","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":51,"lastName":"Levine","length":203.4673,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"Homecoming","status":200,"ts":1541674636796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Barry White","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":6,"lastName":"Brock","length":350.56281,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Come On","status":200,"ts":1541674722796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"John Prine","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":52,"lastName":"Levine","length":136.09751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"He Was In Heaven Before He Died (LP Version)","status":200,"ts":1541674839796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bright Eyes","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":53,"lastName":"Levine","length":375.95383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":342,"song":"I Must Belong Somewhere","status":200,"ts":1541674975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":7,"lastName":"Brock","length":191.55546,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Love Me","status":200,"ts":1541675072796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Darude","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":8,"lastName":"Brock","length":226.08934,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Sandstorm","status":200,"ts":1541675263796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Evanescence","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":9,"lastName":"Brock","length":262.79138,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"My Immortal","status":200,"ts":1541675489796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Harmonia","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":10,"lastName":"Brock","length":655.77751,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Sehr kosmisch","status":200,"ts":1541675751796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"O.G.C.","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":11,"lastName":"Brock","length":290.66404,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Gunn Clapp","status":200,"ts":1541676406796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Mc Chris","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":12,"lastName":"Brock","length":179.51302,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"hoodie ninja","status":200,"ts":1541676696796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Marilyn Manson","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":13,"lastName":"Brock","length":175.77751,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"The Fight Song","status":200,"ts":1541676875796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Red Hot Chili Peppers","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":14,"lastName":"Brock","length":334.65424,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Snow [Hey Oh] (Album Version)","status":200,"ts":1541677050796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"dEUS","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":15,"lastName":"Brock","length":299.83302,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Secret Hell","status":200,"ts":1541677384796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Sean Paul","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":16,"lastName":"Brock","length":183.45751,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Watch Them Roll","status":200,"ts":1541677683796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"These United States","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":17,"lastName":"Brock","length":207.38567,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Heaven Can Wait","status":200,"ts":1541677866796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Tamia","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":18,"lastName":"Brock","length":327.54893,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Careless Whisper","status":200,"ts":1541678073796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":257,"song":null,"status":200,"ts":1541678111796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":257,"song":null,"status":307,"ts":1541678112796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":2,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"Home","registration":1540907087796.0,"sessionId":257,"song":null,"status":200,"ts":1541678143796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Lil Scrappy","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":19,"lastName":"Brock","length":238.78485,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Like Me (Amended Version)","status":200,"ts":1541678400796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Aliz\u00c3\u0083\u00c2\u00a9e","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":0,"lastName":"White","length":266.1873,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":375,"song":"Moi... Lolita","status":200,"ts":1541678588796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Dragonforce","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":20,"lastName":"Brock","length":441.02485,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Through The Fire And Flames (Album Version)","status":200,"ts":1541678638796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Mobb Deep","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":1,"lastName":"White","length":185.80853,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":375,"song":"Backstage Pass","status":200,"ts":1541678854796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":null,"auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Help","registration":1541044398796.0,"sessionId":264,"song":null,"status":200,"ts":1541678863796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Slipknot","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":1,"lastName":"Simpson","length":254.11873,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":264,"song":"Everything Ends (Album Version)","status":200,"ts":1541678864796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Bohren & Der Club Of Gore","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":2,"lastName":"White","length":491.38893,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":375,"song":"Schwarze Biene (Black Maja)","status":200,"ts":1541679039796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Marc Almond","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":21,"lastName":"Brock","length":228.44036,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"The Sea Still Sings","status":200,"ts":1541679079796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Delirious?","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":2,"lastName":"Simpson","length":250.95791,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":264,"song":"Paint The Town Red","status":200,"ts":1541679118796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Red Hot Chili Peppers","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":0,"lastName":"Scott","length":265.50812,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":335,"song":"Under The Bridge (Album Version)","status":200,"ts":1541679196796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":null,"auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":1,"lastName":"Scott","length":null,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"Logout","registration":1540872073796.0,"sessionId":335,"song":null,"status":307,"ts":1541679197796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":335,"song":null,"status":200,"ts":1541679269796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":335,"song":null,"status":200,"ts":1541679287796,"userAgent":null,"userId":""} {"artist":"Bon Iver","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":22,"lastName":"Brock","length":329.24689,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Blindsided","status":200,"ts":1541679307796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"California Swag District","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":3,"lastName":"Simpson","length":239.17669,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":264,"song":"Teach Me How To Dougie","status":200,"ts":1541679368796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Help","registration":null,"sessionId":335,"song":null,"status":200,"ts":1541679387796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":5,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":335,"song":null,"status":307,"ts":1541679388796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":6,"lastName":"Scott","length":null,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"GET","page":"Home","registration":1540872073796.0,"sessionId":335,"song":null,"status":200,"ts":1541679405796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Klaus Badelt","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":3,"lastName":"White","length":136.07138,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":375,"song":"The Black Pearl","status":200,"ts":1541679530796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":null,"auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":4,"lastName":"White","length":null,"level":"free","location":"Lubbock, TX","method":"GET","page":"Home","registration":1540708070796.0,"sessionId":375,"song":null,"status":200,"ts":1541679564796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Yeah Yeah Yeahs","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":23,"lastName":"Brock","length":187.19302,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Gold Lion","status":200,"ts":1541679636796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Basshunter","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":5,"lastName":"White","length":190.30159,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":375,"song":"Patrik och Lillen - Vifta med h\u00c3\u0083\u00c2\u00a4nderna (basshunter remix)","status":200,"ts":1541679666796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Cocteau Twins","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":24,"lastName":"Brock","length":271.85587,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"My Truth","status":200,"ts":1541679823796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Usher featuring will.i.am","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":6,"lastName":"White","length":395.72853,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":375,"song":"OMG","status":200,"ts":1541679856796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Faith No More","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":25,"lastName":"Brock","length":249.86077,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Last Cup Of Sorrow","status":200,"ts":1541680094796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"The Champs","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":7,"lastName":"White","length":132.0224,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":375,"song":"Tequila","status":200,"ts":1541680251796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Disturbed","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":26,"lastName":"Brock","length":200.61995,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Guarded (Album Version)","status":200,"ts":1541680343796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Don Omar","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":27,"lastName":"Brock","length":204.9824,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Dile","status":200,"ts":1541680543796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Alison Krauss \/ Union Station","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":28,"lastName":"Brock","length":190.45832,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"The Lucky One","status":200,"ts":1541680747796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Covenant","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":29,"lastName":"Brock","length":300.19873,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"XRDS","status":200,"ts":1541680937796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"The White Stripes","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":30,"lastName":"Brock","length":231.81016,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Seven Nation Army (Album Version)","status":200,"ts":1541681237796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Carter USM","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":31,"lastName":"Brock","length":109.08689,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"As You Are Leaving The Building","status":200,"ts":1541681468796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Nacho Cano","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":32,"lastName":"Brock","length":195.21261,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"El Dolor Del Agua","status":200,"ts":1541681577796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"The Rumble Strips","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":33,"lastName":"Brock","length":163.52608,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"No Soul","status":200,"ts":1541681772796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Jamie T","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":34,"lastName":"Brock","length":259.65669,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Sheila (Explicit)","status":200,"ts":1541681935796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Jimmy Eat World","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":35,"lastName":"Brock","length":242.93832,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Clarity","status":200,"ts":1541682194796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Jose Gonzalez","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":36,"lastName":"Brock","length":237.53098,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Cycling Trivialities","status":200,"ts":1541682436796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Train","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":37,"lastName":"Brock","length":216.76363,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Hey_ Soul Sister","status":200,"ts":1541682673796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"California Swag District","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":38,"lastName":"Brock","length":239.17669,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":117,"song":"Teach Me How To Dougie","status":200,"ts":1541682889796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Cake","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":319.18975,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":356,"song":"Jolene","status":200,"ts":1541684068796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Fabolous","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":306.442,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":356,"song":"Can't Deny It [featuring Nate Dogg] [Explicit Version]","status":200,"ts":1541684387796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Crosby_ Stills & Nash","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":159.11138,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":330,"song":"Marrakesh Express (LP Version)","status":200,"ts":1541684775796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"Violent Femmes","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":1,"lastName":"Johnson","length":284.3424,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":330,"song":"Add It Up","status":200,"ts":1541684934796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":348,"song":null,"status":200,"ts":1541684960796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":348,"song":null,"status":200,"ts":1541684998796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Settings","registration":1541033612796.0,"sessionId":348,"song":null,"status":200,"ts":1541685017796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Help","registration":1541033612796.0,"sessionId":348,"song":null,"status":200,"ts":1541685048796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540492941796.0,"sessionId":302,"song":null,"status":200,"ts":1541685089796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Calle 13","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":2,"lastName":"Johnson","length":228.72771,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":330,"song":"Sin Coro","status":200,"ts":1541685218796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":372,"song":null,"status":200,"ts":1541686190796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":372,"song":null,"status":307,"ts":1541686191796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":2,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":372,"song":null,"status":200,"ts":1541686235796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Radars to the Sky","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":3,"lastName":"Lynch","length":216.16281,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"Victoria","status":200,"ts":1541686302796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Lonely Island","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":4,"lastName":"Lynch","length":174.15791,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"Incredibad","status":200,"ts":1541686518796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":5,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":372,"song":null,"status":200,"ts":1541686537796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":6,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Settings","registration":1540223723796.0,"sessionId":372,"song":null,"status":200,"ts":1541686603796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Skint & Demoralised","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":7,"lastName":"Lynch","length":245.7073,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"Three More Days","status":200,"ts":1541686692796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Faith No More","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":8,"lastName":"Lynch","length":158.9024,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"What A Day","status":200,"ts":1541686937796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Eagles Of Death Metal","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":9,"lastName":"Lynch","length":169.74322,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"Speaking In Tongues","status":200,"ts":1541687095796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Metallica","auth":"Logged In","firstName":"Sienna","gender":"F","itemInSession":0,"lastName":"Colon","length":415.16363,"level":"free","location":"Las Cruces, NM","method":"PUT","page":"NextSong","registration":1540013692796.0,"sessionId":317,"song":"Fade To Black","status":200,"ts":1541687228796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"81"} {"artist":"Angels and Airwaves","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":10,"lastName":"Lynch","length":302.05342,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"The Gift","status":200,"ts":1541687264796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Woven Hand","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":11,"lastName":"Lynch","length":210.83383,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"Swedish Purse","status":200,"ts":1541687566796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Decemberists","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":12,"lastName":"Lynch","length":242.59873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"Everything I Try to Do_ Nothing Seems to Turn Out Right","status":200,"ts":1541687776796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Looptroop","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":13,"lastName":"Lynch","length":319.32036,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"Long Arm Of The Law","status":200,"ts":1541688018796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Cheb Mami - K-Maro","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":191.73832,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":370,"song":"Nos Couleurs (Feat K Maro)","status":200,"ts":1541688167796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Tab Benoit","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":0,"lastName":"Jones","length":221.09995,"level":"free","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":178,"song":"Jambalaya","status":200,"ts":1541688225796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Kim Carnes","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":14,"lastName":"Lynch","length":223.242,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"Bette Davis Eyes","status":200,"ts":1541688337796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Clutch","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":1,"lastName":"Jones","length":358.53016,"level":"free","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":178,"song":"Drink To The Dead (LP Version)","status":200,"ts":1541688446796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":2,"lastName":"Jones","length":null,"level":"free","location":"Janesville-Beloit, WI","method":"PUT","page":"Logout","registration":1541062818796.0,"sessionId":178,"song":null,"status":307,"ts":1541688447796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":178,"song":null,"status":200,"ts":1541688515796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":178,"song":null,"status":307,"ts":1541688516796,"userAgent":null,"userId":""} {"artist":"Justice","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":15,"lastName":"Lynch","length":285.41342,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"Phantom Part 1.5 (Album Version)","status":200,"ts":1541688560796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":5,"lastName":"Jones","length":null,"level":"free","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":178,"song":null,"status":200,"ts":1541688599796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Fall Out Boy","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":6,"lastName":"Jones","length":181.36771,"level":"free","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":178,"song":"Dance_ Dance","status":200,"ts":1541688804796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Vienna Teng","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":16,"lastName":"Lynch","length":263.78404,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"Harbor","status":200,"ts":1541688845796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Fat Joe","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":7,"lastName":"Jones","length":317.09995,"level":"free","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":178,"song":"Story To Tell","status":200,"ts":1541688985796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Muse","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":17,"lastName":"Lynch","length":209.34485,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"Supermassive Black Hole (Album Version)","status":200,"ts":1541689108796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Smiths","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":18,"lastName":"Lynch","length":196.67546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":372,"song":"The Boy With The Thorn In His Side","status":200,"ts":1541689317796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Beach House","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":265.1424,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":383,"song":"Heart of Chambers","status":200,"ts":1541689769796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Galactic","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":128.39138,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":383,"song":"Wild Man (featuring Big Chief Bo Dollis)","status":200,"ts":1541690034796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Static-X","auth":"Logged In","firstName":"Adelyn","gender":"F","itemInSession":0,"lastName":"Jordan","length":183.69261,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1540130971796.0,"sessionId":6,"song":"Dirthouse (Album Version)","status":200,"ts":1541691894796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"7"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":0,"lastName":"Jones","length":null,"level":"free","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":388,"song":null,"status":200,"ts":1541692094796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Pulp","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":1,"lastName":"Jones","length":244.08771,"level":"free","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":388,"song":"Babies","status":200,"ts":1541692145796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":0,"lastName":"George","length":null,"level":"free","location":"Birmingham-Hoover, AL","method":"GET","page":"Home","registration":1541020249796.0,"sessionId":327,"song":null,"status":200,"ts":1541699135796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"K-OS","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":211.33016,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":382,"song":"EMCEE Murdah","status":200,"ts":1541700032796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":0,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":289,"song":null,"status":200,"ts":1541701146796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Oleta Adams","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":0,"lastName":"Taylor","length":281.93914,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":290,"song":"My Heart Won't Lie","status":200,"ts":1541701401796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":376,"song":null,"status":200,"ts":1541702767796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Afromental","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":196.20526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":376,"song":"Bootycall","status":200,"ts":1541703382796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"NOFX","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":65.04444,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":394,"song":"Benny Got Blowed Up","status":200,"ts":1541703422796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Girl Talk","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":173.24363,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":376,"song":"Give and Go","status":200,"ts":1541703578796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Scars On Broadway","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":175.46404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":376,"song":"Funny","status":200,"ts":1541703751796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Wilco","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":363.96363,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":376,"song":"I Am Trying to Break Your Heart","status":200,"ts":1541703926796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Hawk Nelson","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":174.81098,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":376,"song":"California","status":200,"ts":1541704289796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"DAVE MATTHEWS BAND","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":341.26322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":376,"song":"So Much To Say","status":200,"ts":1541704463796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"System of a Down","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":169.89995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":376,"song":"Lonely Day","status":200,"ts":1541704804796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"McFly","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":267.62404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":376,"song":"Falling In Love","status":200,"ts":1541704973796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Death In Vegas","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":270.23628,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":376,"song":"Girls","status":200,"ts":1541705240796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Silverchair","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":0,"lastName":"Harris","length":257.72363,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":358,"song":"Straight Lines","status":200,"ts":1541705799796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":null,"auth":"Logged In","firstName":"Carlos","gender":"M","itemInSession":0,"lastName":"Carter","length":null,"level":"free","location":"Miami-Fort Lauderdale-West Palm Beach, FL","method":"GET","page":"Home","registration":1540891212796.0,"sessionId":292,"song":null,"status":200,"ts":1541709292796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"27"} {"artist":"Sean Kingston and Justin Bieber","auth":"Logged In","firstName":"Carlos","gender":"M","itemInSession":1,"lastName":"Carter","length":201.9522,"level":"free","location":"Miami-Fort Lauderdale-West Palm Beach, FL","method":"PUT","page":"NextSong","registration":1540891212796.0,"sessionId":292,"song":"Eenie Meenie","status":200,"ts":1541709314796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"27"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":0,"lastName":"George","length":null,"level":"free","location":"Birmingham-Hoover, AL","method":"GET","page":"Home","registration":1541020249796.0,"sessionId":393,"song":null,"status":200,"ts":1541713312796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Andr\u00c3\u0083\u00c2\u00a9s Cepeda","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":1,"lastName":"George","length":203.96363,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":393,"song":"C\u00c3\u0083\u00c2\u00b3mo Puede Ser","status":200,"ts":1541713318796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Dominick","gender":"M","itemInSession":0,"lastName":"Norris","length":null,"level":"free","location":"Los Angeles-Long Beach-Anaheim, CA","method":"GET","page":"Home","registration":1540975502796.0,"sessionId":365,"song":null,"status":200,"ts":1541713353796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"45"} {"artist":null,"auth":"Logged In","firstName":"Dominick","gender":"M","itemInSession":1,"lastName":"Norris","length":null,"level":"free","location":"Los Angeles-Long Beach-Anaheim, CA","method":"GET","page":"Settings","registration":1540975502796.0,"sessionId":365,"song":null,"status":200,"ts":1541713358796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"45"} {"artist":"Irish Tenors","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":2,"lastName":"George","length":187.48036,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":393,"song":"Danny Boy","status":200,"ts":1541713521796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":3,"lastName":"George","length":212.53179,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":393,"song":"Runaway Love","status":200,"ts":1541713708796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Dominick","gender":"M","itemInSession":0,"lastName":"Norris","length":null,"level":"free","location":"Los Angeles-Long Beach-Anaheim, CA","method":"GET","page":"Home","registration":1540975502796.0,"sessionId":401,"song":null,"status":200,"ts":1541719996796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"45"} {"artist":"Jonny L","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":0,"lastName":"Barrett","length":401.52771,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Microdaze","status":200,"ts":1541721576796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"}
457.381166
538
0.697813
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Muse","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":1,"lastName":"Barrett","length":209.50159,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Supermassive Black Hole (Twilight Soundtrack Version)","status":200,"ts":1541721977796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":2,"lastName":"Barrett","length":161.56689,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Lighten Up","status":200,"ts":1541722186796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Shakira","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":3,"lastName":"Barrett","length":145.84118,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Pienso En Ti","status":200,"ts":1541722347796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Selena","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":4,"lastName":"Barrett","length":172.66893,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Amor Prohibido","status":200,"ts":1541722492796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Kid Cudi Vs Crookers","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":5,"lastName":"Barrett","length":162.97751,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Day 'N' Nite","status":200,"ts":1541722664796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Rise Against","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":6,"lastName":"Barrett","length":179.59138,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Black Masks & Gasoline","status":200,"ts":1541722826796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Fall Out Boy","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":7,"lastName":"Barrett","length":211.69587,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"I'm Like A Lawyer With The Way I'm Always Trying To Get You Off (Me & You)","status":200,"ts":1541723005796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":8,"lastName":"Barrett","length":196.12689,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Staple It Together","status":200,"ts":1541723216796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Twista feat. Kayne West & Jamie Foxx","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":9,"lastName":"Barrett","length":212.55791,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Slow Jamz (Feat. Kanye West & Jamie Foxx) (Edited Album Version)","status":200,"ts":1541723412796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Train","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":10,"lastName":"Barrett","length":216.76363,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Hey_ Soul Sister","status":200,"ts":1541723624796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Rihanna","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":11,"lastName":"Barrett","length":293.82485,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Rehab","status":200,"ts":1541723840796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Man Man","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":12,"lastName":"Barrett","length":222.45832,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Van Helsing Boombox","status":200,"ts":1541724133796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Ween","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":13,"lastName":"Barrett","length":276.13995,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"The Stallion","status":200,"ts":1541724355796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Charttraxx Karaoke","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":14,"lastName":"Barrett","length":225.17506,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Fireflies","status":200,"ts":1541724631796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Digitalism","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":15,"lastName":"Barrett","length":208.24771,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"I Want I Want","status":200,"ts":1541724856796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Dispatch","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":16,"lastName":"Barrett","length":247.50975,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Railway","status":200,"ts":1541725064796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Postal Service","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":17,"lastName":"Barrett","length":294.47791,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Clark Gable (Album)","status":200,"ts":1541725311796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Patricia Barber","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":18,"lastName":"Barrett","length":317.83138,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Phaeton","status":200,"ts":1541725605796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Enur","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":19,"lastName":"Barrett","length":203.4673,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Ucci Ucci feat. Nicki Minaj & The Chopper City Boyz","status":200,"ts":1541725922796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Hybrid","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":20,"lastName":"Barrett","length":379.61098,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Choke","status":200,"ts":1541726125796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Riverside","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":21,"lastName":"Barrett","length":236.2771,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Stuck Between","status":200,"ts":1541726504796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Enigma","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":22,"lastName":"Barrett","length":272.48281,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Smell Of Desire.","status":200,"ts":1541726740796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Arcade Fire","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":23,"lastName":"Barrett","length":267.80689,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Headlights Look Like Diamonds","status":200,"ts":1541727012796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":null,"auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":24,"lastName":"Barrett","length":null,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Help","registration":1540685364796.0,"sessionId":275,"song":null,"status":200,"ts":1541727027796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Spoon","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":25,"lastName":"Barrett","length":274.36363,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Out Go The Lights","status":200,"ts":1541727279796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"The Wannadies","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":26,"lastName":"Barrett","length":170.86649,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"You & Me Song","status":200,"ts":1541727553796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Tricky","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":27,"lastName":"Barrett","length":261.43302,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Girls (Album version)","status":200,"ts":1541727723796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Tony Rice","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":28,"lastName":"Barrett","length":321.98485,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Wayfaring Stranger","status":200,"ts":1541727984796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Rasheeda","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":29,"lastName":"Barrett","length":212.40118,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Sweep The Flo (Featuring Diamond)","status":200,"ts":1541728305796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"George Younce","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":30,"lastName":"Barrett","length":191.68608,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"This Old House w\/ When The Saints Medley","status":200,"ts":1541728517796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Alex Gopher","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":31,"lastName":"Barrett","length":221.6224,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Brain Leech","status":200,"ts":1541728708796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Aphex Twin","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":32,"lastName":"Barrett","length":430.18404,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"Didgeridoo","status":200,"ts":1541728929796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Emmanuel Moire","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":33,"lastName":"Barrett","length":277.08036,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"L\u00c3\u0083\u00c2\u00a0 O\u00c3\u0083\u00c2\u00b9 Je Pars","status":200,"ts":1541729359796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Josh Turner","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":34,"lastName":"Barrett","length":212.16608,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":275,"song":"I Wouldn't Be A Man","status":200,"ts":1541729636796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Carlos Y Jos\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":166.45179,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":336,"song":"Soy Alba\u00c3\u0083\u00c2\u00b1il","status":200,"ts":1541730101796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Motionless in White","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":217.57342,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":288,"song":"Ghost In The Mirror","status":200,"ts":1541730128796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Feist","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":0,"lastName":"Griffin","length":184.94649,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":395,"song":"My Moon My Man","status":200,"ts":1541737556796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":1,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":395,"song":null,"status":200,"ts":1541737694796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Postal Service","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":300.53832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":398,"song":"We Will Become Silhouettes (Album)","status":200,"ts":1541743962796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":390,"song":null,"status":200,"ts":1541744253796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Stevie Ray Vaughan And Double Trouble","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":258.82077,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":398,"song":"Life Without You","status":200,"ts":1541744262796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"AFI","auth":"Logged In","firstName":"Hannah","gender":"F","itemInSession":0,"lastName":"Calhoun","length":176.48281,"level":"free","location":"Los Angeles-Long Beach-Anaheim, CA","method":"PUT","page":"NextSong","registration":1540583221796.0,"sessionId":166,"song":"Miseria Cantare--The Beginning","status":200,"ts":1541751689796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_1 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D201 Safari\/9537.53\"","userId":"64"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":276,"song":null,"status":200,"ts":1541763743796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":276,"song":null,"status":307,"ts":1541763744796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":2,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Home","registration":1540809153796.0,"sessionId":276,"song":null,"status":200,"ts":1541763829796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Lonnie Gordon","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":3,"lastName":"Johnson","length":181.21098,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":276,"song":"Catch You Baby (Steve Pitron & Max Sanna Radio Edit)","status":200,"ts":1541763875796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Harry Connick_ Jr.","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":4,"lastName":"Johnson","length":197.09342,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":276,"song":"My Blue Heaven","status":200,"ts":1541764056796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Andres Calamaro","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":5,"lastName":"Johnson","length":122.33098,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":276,"song":"Crucificame","status":200,"ts":1541764253796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":6,"lastName":"Johnson","length":233.69098,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":276,"song":"Invalid","status":200,"ts":1541764375796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Brian Poole & The Tremeloes","auth":"Logged In","firstName":"Kimber","gender":"F","itemInSession":0,"lastName":"Norris","length":115.66975,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540975589796.0,"sessionId":142,"song":"I Can Dance","status":200,"ts":1541768834796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"47"} {"artist":"War","auth":"Logged In","firstName":"Kimber","gender":"F","itemInSession":1,"lastName":"Norris","length":244.03546,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540975589796.0,"sessionId":142,"song":"The World Is A Ghetto","status":200,"ts":1541768949796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"47"} {"artist":null,"auth":"Logged In","firstName":"Kimber","gender":"F","itemInSession":2,"lastName":"Norris","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"About","registration":1540975589796.0,"sessionId":142,"song":null,"status":200,"ts":1541768981796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"47"} {"artist":"Kanye West \/ Consequence \/ Cam'Ron","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":333.34812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"Gone","status":200,"ts":1541771196796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"David Banner","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":232.75057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"Play","status":200,"ts":1541771529796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kreator","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":0,"lastName":"Larson","length":287.9473,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":271,"song":"Second awakening","status":200,"ts":1541771755796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"Cipher","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":311.2224,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"Protoculture (Sankofa)","status":200,"ts":1541771761796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":416.522,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"Emotion","status":200,"ts":1541772072796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":0,"lastName":"Santana","length":233.89995,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":66,"song":"Love Story","status":200,"ts":1541772225796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"The Police","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":289.2273,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"Message In A Bottle","status":200,"ts":1541772488796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"JayMay","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":590.91546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"You'd Rather Run","status":200,"ts":1541772777796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":0,"lastName":"Johnson","length":null,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"GET","page":"Home","registration":1541081807796.0,"sessionId":331,"song":null,"status":200,"ts":1541773232796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"Amy Adams","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":1,"lastName":"Johnson","length":128.62649,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":331,"song":"Happy Working Song","status":200,"ts":1541773271796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"Shinedown","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":220.39465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"Second Chance (Album Version)","status":200,"ts":1541773367796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":2,"lastName":"Johnson","length":141.24363,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":331,"song":"Some Unholy War","status":200,"ts":1541773399796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"T.I. & DJ Drama","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":245.9424,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"Ride Wit Me","status":200,"ts":1541773587796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Gang Starr","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Koch","length":194.2722,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":362,"song":"Soliloquy Of Chaos (Explicit)","status":200,"ts":1541773782796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":362,"song":null,"status":200,"ts":1541773818796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Benny Benassi","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":207.49016,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"Who's Your Daddy? ","status":200,"ts":1541773832796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Paramore","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Koch","length":215.09179,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":362,"song":"When It Rains (Album Version)","status":200,"ts":1541773976796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Metallica","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":319.73832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"Mama Said","status":200,"ts":1541774039796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"A-Ha","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Koch","length":246.25587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":362,"song":"Forever Not Yours (Album Version - NY Mix II)","status":200,"ts":1541774191796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Easy Star All-Stars","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":244.81914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"Lovely Rita (feat. Bunny Rugs and U Roy)","status":200,"ts":1541774358796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Alter Bridge","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Koch","length":286.35383,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":362,"song":"Down To My Last","status":200,"ts":1541774437796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"O Terco","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":431.20281,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"Mudanca De Tempo","status":200,"ts":1541774602796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Nightwish","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":5,"lastName":"Koch","length":330.97098,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":362,"song":"Walking In The Air","status":200,"ts":1541774723796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Augustana","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":196.70159,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"Mayfield","status":200,"ts":1541775033796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Anita Ward","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":6,"lastName":"Koch","length":491.93751,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":362,"song":"Ring My Bell","status":200,"ts":1541775053796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Gaz Nevada","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":390.21669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"I C Love Affair","status":200,"ts":1541775229796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Flamin' Groovies","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":7,"lastName":"Koch","length":299.65016,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":362,"song":"Slow Death","status":200,"ts":1541775544796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":8,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Settings","registration":1541048010796.0,"sessionId":362,"song":null,"status":200,"ts":1541775555796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":9,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"Save Settings","registration":1541048010796.0,"sessionId":362,"song":null,"status":307,"ts":1541775556796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"isis","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":406.12526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":409,"song":"Carry","status":200,"ts":1541775619796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":10,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":362,"song":null,"status":200,"ts":1541775811796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":11,"lastName":"Koch","length":236.09424,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":362,"song":"Canada","status":200,"ts":1541775843796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Frankie HI-NRG MC","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":12,"lastName":"Koch","length":104.09751,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":362,"song":"Pace E Guerra","status":200,"ts":1541776079796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":252.21179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1541776602796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Pavement","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":99.16036,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Mercy:The Laundromat","status":200,"ts":1541776854796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"4 Skins","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":165.51138,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Clockwork Skinhead","status":200,"ts":1541776953796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Thrice","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":249.46893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Wood And Wire","status":200,"ts":1541777118796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Van Halen","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":289.38404,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":408,"song":"Best Of Both Worlds (Remastered Album Version)","status":200,"ts":1541777153796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Harris","length":277.15873,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":340,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1541777159796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Hot Chip","auth":"Logged In","firstName":"Ann","gender":"F","itemInSession":0,"lastName":"Banks","length":230.29506,"level":"free","location":"Salt Lake City, UT","method":"PUT","page":"NextSong","registration":1540895683796.0,"sessionId":227,"song":"My Brother Is Watching Me","status":200,"ts":1541777355796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"99"} {"artist":"Lasgo","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":192.80934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Over You","status":200,"ts":1541777367796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Peter Sellers","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":142.39302,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":408,"song":"She Loves You","status":200,"ts":1541777442796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Alphaville","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":285.43955,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":363,"song":"Big In Japan (Original)","status":200,"ts":1541777488796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Eneida Marta","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":223.55546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Mindjer d\u00c3\u0083\u00c2\u00b4ce mel","status":200,"ts":1541777559796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Astral Projection","auth":"Logged In","firstName":"Ann","gender":"F","itemInSession":1,"lastName":"Banks","length":585.42975,"level":"free","location":"Salt Lake City, UT","method":"PUT","page":"NextSong","registration":1540895683796.0,"sessionId":227,"song":"Flying Into a Star","status":200,"ts":1541777585796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"99"} {"artist":"Gare du Nord","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":221.98812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Marvin & Miles","status":200,"ts":1541777782796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":219.66322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1541778003796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The White Stripes","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":232.61995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Seven Nation Army","status":200,"ts":1541778222796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bouncing Souls","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":66.01098,"level":"free","location":"London, KY","method":"PUT","page":"NextSong","registration":1540613280796.0,"sessionId":108,"song":"East Side Mags","status":200,"ts":1541778360796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"13"} {"artist":"Coldplay","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":311.27465,"level":"free","location":"London, KY","method":"PUT","page":"NextSong","registration":1540613280796.0,"sessionId":108,"song":"The Scientist","status":200,"ts":1541778426796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"13"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":201.79546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Revelry","status":200,"ts":1541778454796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mad Caddies","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":181.81179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Backyard","status":200,"ts":1541778655796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Phil Collins","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":239.85587,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":406,"song":"The Way You Look Tonight (Live Version)","status":200,"ts":1541778722796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Parachute","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":230.5824,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"The Mess I Made","status":200,"ts":1541778836796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":0,"lastName":"Young","length":null,"level":"free","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":368,"song":null,"status":200,"ts":1541779046796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Escape The Fate","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":1,"lastName":"Young","length":283.34975,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"My Apocalypse","status":200,"ts":1541779046796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Booka Shade","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":336.45669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Teenage Spaceman","status":200,"ts":1541779066796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":2,"lastName":"Young","length":null,"level":"free","location":"Red Bluff, CA","method":"GET","page":"Upgrade","registration":1540465241796.0,"sessionId":368,"song":null,"status":200,"ts":1541779072796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":3,"lastName":"Young","length":null,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"Submit Upgrade","registration":1540465241796.0,"sessionId":368,"song":null,"status":307,"ts":1541779073796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":4,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":368,"song":null,"status":200,"ts":1541779151796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Modern Lovers","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":5,"lastName":"Young","length":180.27057,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Modern world","status":200,"ts":1541779329796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":233.69098,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":423,"song":"Invalid","status":200,"ts":1541779387796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Black Box","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":247.03955,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Everybody Everybody","status":200,"ts":1541779402796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Cass Phang","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":6,"lastName":"Young","length":249.05098,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Ye Feng Ling","status":200,"ts":1541779509796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":277.15873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1541779649796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Adina Howard","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":7,"lastName":"Young","length":210.33751,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Buttnaked","status":200,"ts":1541779758796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Queens Of The Stone Age","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":254.77179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"No One Knows","status":200,"ts":1541779926796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mondo Marcio","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":8,"lastName":"Young","length":218.06975,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Il Solo Rimasto","status":200,"ts":1541779968796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Steve Miller Band","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":242.46812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Living In The U.S.A. (1991 Digital Remaster)","status":200,"ts":1541780180796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Lil Wayne \/ Eminem","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":9,"lastName":"Young","length":229.58975,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Drop The World","status":200,"ts":1541780186796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"4hero feat. FACE","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":10,"lastName":"Young","length":304.71791,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Stoke Up The Fire","status":200,"ts":1541780415796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Toby Keith","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":238.44526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Whiskey Girl","status":200,"ts":1541780422796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Los Fabulosos Cadillacs","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":18,"lastName":"Levine","length":353.93261,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Muy_ Muy Temprano","status":200,"ts":1541780660796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Amon Amarth","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":11,"lastName":"Young","length":257.27955,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Under The Northern Star","status":200,"ts":1541780719796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Markus Kruneg\u00c3\u0083\u00c2\u00a5rd","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":0,"lastName":"Rogers","length":185.5473,"level":"free","location":"San Diego-Carlsbad, CA","method":"PUT","page":"NextSong","registration":1540976199796.0,"sessionId":17,"song":"Genom tunna tyger","status":200,"ts":1541780768796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_2) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"18"} {"artist":"Michael B.","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":1,"lastName":"Rogers","length":197.3024,"level":"free","location":"San Diego-Carlsbad, CA","method":"PUT","page":"NextSong","registration":1540976199796.0,"sessionId":17,"song":"Geh Deinen Weg","status":200,"ts":1541780953796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_2) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"18"} {"artist":"The Serendipity Singers","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":12,"lastName":"Young","length":163.21261,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Don't Let The Rain Come Down (Crooked Little Man)","status":200,"ts":1541780976796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Sheena Easton","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":19,"lastName":"Levine","length":239.62077,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Strut (1993 Digital Remaster)","status":200,"ts":1541781013796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Skillet","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":13,"lastName":"Young","length":210.02404,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Falling Inside The Black (Album Version)","status":200,"ts":1541781139796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Bevis Frond","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":20,"lastName":"Levine","length":265.32526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Into The Cryptic Mist","status":200,"ts":1541781252796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kingston Trio","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":14,"lastName":"Young","length":193.07057,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Greenback Dollar","status":200,"ts":1541781349796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":21,"lastName":"Levine","length":269.29587,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Ten Cent Pistol","status":200,"ts":1541781517796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":15,"lastName":"Young","length":141.87057,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Times Like These","status":200,"ts":1541781542796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Great White","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":16,"lastName":"Young","length":357.14567,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"House Of Broken Love","status":200,"ts":1541781683796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Blind Melon","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":22,"lastName":"Levine","length":217.15546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"No Rain","status":200,"ts":1541781786796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Aerosmith","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":301.76608,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":420,"song":"Fly Away From Here","status":200,"ts":1541781964796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"311","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":23,"lastName":"Levine","length":191.79057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Solar Flare","status":200,"ts":1541782003796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Haloo Helsinki!","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":17,"lastName":"Young","length":223.42485,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Kaaos ei karkaa","status":200,"ts":1541782040796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Dakota Oak","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":24,"lastName":"Levine","length":45.63546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Baker's Blue Jay Yarn","status":200,"ts":1541782194796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bow Wow feat. Chris Brown and Johnt\u00c3\u0083\u00c2\u00a1 Austin","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":25,"lastName":"Levine","length":268.06812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Shortie Like Mine","status":200,"ts":1541782239796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Angus & Julia Stone","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":18,"lastName":"Young","length":265.29914,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Hold On","status":200,"ts":1541782263796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Rammstein","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":26,"lastName":"Levine","length":228.46649,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Adios","status":200,"ts":1541782507796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Avett Brothers","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":19,"lastName":"Young","length":233.84771,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Shame","status":200,"ts":1541782528796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Jose Cid","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":27,"lastName":"Levine","length":202.23955,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Madrugada Na Praia Deserta","status":200,"ts":1541782735796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"A Perfect Circle","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":20,"lastName":"Young","length":291.52608,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":368,"song":"Vanishing","status":200,"ts":1541782761796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Ron Carter","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":28,"lastName":"Levine","length":497.13587,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"I CAN'T GET STARTED","status":200,"ts":1541782937796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Muse","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":29,"lastName":"Levine","length":255.08526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Do We Need This?","status":200,"ts":1541783434796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":30,"lastName":"Levine","length":191.76444,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Howlin\u0019 For You","status":200,"ts":1541783689796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":0,"lastName":"Barrera","length":164.41424,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":341,"song":"Bleed It Out (Album Version)","status":200,"ts":1541783821796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Jonny L","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":31,"lastName":"Levine","length":401.52771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Microdaze","status":200,"ts":1541783880796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Dangerdoom","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":32,"lastName":"Levine","length":146.85995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Crosshairs","status":200,"ts":1541784281796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":33,"lastName":"Levine","length":212.68853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Breakdown","status":200,"ts":1541784427796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":34,"lastName":"Levine","length":271.38567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"The Pretender","status":200,"ts":1541784639796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Sleater-kinney","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":35,"lastName":"Levine","length":264.4371,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Jumpers (Album)","status":200,"ts":1541784910796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Interpol","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":36,"lastName":"Levine","length":276.63628,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Pace Is The Trick","status":200,"ts":1541785174796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Leonard Cohen","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":37,"lastName":"Levine","length":365.94893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Dance Me To The End Of Love","status":200,"ts":1541785450796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Art Pepper","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":0,"lastName":"Jones","length":311.90159,"level":"free","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Star Eyes","status":200,"ts":1541785625796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Trapt","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":38,"lastName":"Levine","length":285.98812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Headstrong (Album Version)","status":200,"ts":1541785815796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Sidewalk Prophets","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":1,"lastName":"Jones","length":260.62322,"level":"free","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"You Love Me Anyway (Album)","status":200,"ts":1541785936796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":2,"lastName":"Jones","length":null,"level":"free","location":"Janesville-Beloit, WI","method":"GET","page":"Upgrade","registration":1541062818796.0,"sessionId":392,"song":null,"status":200,"ts":1541785936796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":3,"lastName":"Jones","length":null,"level":"free","location":"Janesville-Beloit, WI","method":"PUT","page":"Submit Upgrade","registration":1541062818796.0,"sessionId":392,"song":null,"status":307,"ts":1541785937796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":4,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":392,"song":null,"status":200,"ts":1541786057796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Pearl Jam","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":39,"lastName":"Levine","length":352.88771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Not For You","status":200,"ts":1541786100796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Nach","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":5,"lastName":"Jones","length":182.41261,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"El Juego Del Rap","status":200,"ts":1541786196796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"U.S. Bombs","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":214.85669,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":360,"song":"U.S. Bombs","status":200,"ts":1541786274796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Vasco Rossi","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":6,"lastName":"Jones","length":233.53424,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Colpa Del Whisky (Andrea Paci Radio Edit)","status":200,"ts":1541786378796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Bruce Springsteen","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":40,"lastName":"Levine","length":195.7873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Streets Of Philadelphia","status":200,"ts":1541786452796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Usher","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":224.10404,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":360,"song":"Hey Daddy (Daddy's Home)","status":200,"ts":1541786488796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":41,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":416,"song":null,"status":200,"ts":1541786530796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Martin Orford","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":7,"lastName":"Jones","length":597.55057,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Grand Designs","status":200,"ts":1541786611796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Curtis Stigers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":42,"lastName":"Levine","length":259.49995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Columbus Avenue","status":200,"ts":1541786647796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Man\u00c3\u0083\u00c2\u00a1","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":2,"lastName":"Robinson","length":262.81751,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":360,"song":"Mariposa traicionera","status":200,"ts":1541786712796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Mariah Carey","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":242.18077,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":397,"song":"Obsessed","status":200,"ts":1541786857796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":43,"lastName":"Levine","length":236.93016,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Bubble Toes","status":200,"ts":1541786906796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bill Withers","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":3,"lastName":"Robinson","length":383.73832,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":360,"song":"Make Love To Your Mind","status":200,"ts":1541786974796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Postal Service","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":307.53914,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":397,"song":"Natural Anthem (Album)","status":200,"ts":1541787099796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Sara Bareilles","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":44,"lastName":"Levine","length":253.02159,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Love On The Rocks","status":200,"ts":1541787142796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Gillian Welch","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":8,"lastName":"Jones","length":237.26975,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Pass You By","status":200,"ts":1541787208796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":null,"level":"free","location":"Santa Rosa, CA","method":"GET","page":"Home","registration":1540880381796.0,"sessionId":385,"song":null,"status":200,"ts":1541787281796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"M83","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":4,"lastName":"Robinson","length":367.5424,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":360,"song":"Gone","status":200,"ts":1541787357796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Okkervil River","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":278.54322,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":397,"song":"Unless It's Kicks","status":200,"ts":1541787406796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"1200 Mics","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":9,"lastName":"Jones","length":483.39546,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"DNA","status":200,"ts":1541787445796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":45,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Downgrade","registration":1540794356796.0,"sessionId":416,"song":null,"status":200,"ts":1541787760796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Chasen","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":46,"lastName":"Levine","length":166.16444,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Crazy Beautiful","status":200,"ts":1541787760796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jonas Steur","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":47,"lastName":"Levine","length":481.38404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Sonrisa","status":200,"ts":1541787926796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Franz Ferdinand","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":10,"lastName":"Jones","length":204.14649,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Call Me","status":200,"ts":1541787928796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Recycler","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":11,"lastName":"Jones","length":323.52608,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Kromozom Bankal (Linathaleyco Mix)","status":200,"ts":1541788132796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":431,"song":null,"status":200,"ts":1541788265796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Red Hot Chili Peppers","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":107.31057,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":431,"song":"Pea (Album Version)","status":200,"ts":1541788265796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Sunny Day Real Estate","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":198.97424,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":431,"song":"Red Elephant","status":200,"ts":1541788372796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":0,"lastName":"Rogers","length":null,"level":"free","location":"San Diego-Carlsbad, CA","method":"GET","page":"Home","registration":1540976199796.0,"sessionId":425,"song":null,"status":200,"ts":1541788394796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_2) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"18"} {"artist":"Alice In Chains","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":48,"lastName":"Levine","length":282.30485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"Your Decision","status":200,"ts":1541788407796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bell Orchestre","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":12,"lastName":"Jones","length":137.82159,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Stripes","status":200,"ts":1541788455796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":1,"lastName":"Rogers","length":494.99383,"level":"free","location":"San Diego-Carlsbad, CA","method":"PUT","page":"NextSong","registration":1540976199796.0,"sessionId":425,"song":"Bleed It Out [Live At Milton Keynes]","status":200,"ts":1541788457796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_2) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"18"} {"artist":"Sam Cooke","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":3,"lastName":"Smith","length":122.04363,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":431,"song":"Ain't Misbehavin","status":200,"ts":1541788570796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Sunny Day Real Estate","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":13,"lastName":"Jones","length":253.43955,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Every Shining Time You Arrive (Album)","status":200,"ts":1541788592796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Eminem","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":49,"lastName":"Levine","length":212.00934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":416,"song":"I'm Shady","status":200,"ts":1541788689796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Westside Connection","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":14,"lastName":"Jones","length":223.60771,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Call 9-1-1 (Explicit)","status":200,"ts":1541788845796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Kitty Wells & Roy Drusky","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":15,"lastName":"Jones","length":140.64281,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Remember Me_ I'm The One Who Loves You","status":200,"ts":1541789068796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Big Shug","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":16,"lastName":"Jones","length":140.56444,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"It Just Don't Stop","status":200,"ts":1541789208796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Miguel Calo","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":17,"lastName":"Jones","length":171.17995,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"El Cuatrero","status":200,"ts":1541789348796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Jimi Hendrix","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":18,"lastName":"Jones","length":241.24036,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"All Along The Watchtower","status":200,"ts":1541789519796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Mangataot","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":19,"lastName":"Jones","length":356.62322,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Kalidafun Parts 1&2","status":200,"ts":1541789760796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Scott Walker","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":20,"lastName":"Jones","length":199.6273,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Rosemary","status":200,"ts":1541790116796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Styx","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":21,"lastName":"Jones","length":247.64036,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Blue Collar Man (Long Nights)","status":200,"ts":1541790315796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Aventura","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":22,"lastName":"Jones","length":240.43057,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Su veneno","status":200,"ts":1541790562796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Katy Perry","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":23,"lastName":"Jones","length":233.53424,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Hot N Cold (Manhattan Clique Remix Radio Edit)","status":200,"ts":1541790802796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":24,"lastName":"Jones","length":210.15465,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Bebot","status":200,"ts":1541791035796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":25,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":392,"song":null,"status":200,"ts":1541791138796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Boys Noize","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":26,"lastName":"Jones","length":256.60036,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Lava Lava","status":200,"ts":1541791245796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":434,"song":null,"status":200,"ts":1541791377796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"James Blake","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":27,"lastName":"Jones","length":248.78975,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Air & Lack Thereof","status":200,"ts":1541791501796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Aqua","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":217.57342,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":434,"song":"My Mamma Said","status":200,"ts":1541791618796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Emil Gilels\/Orchestre de la Soci\u00c3\u0083\u00c2\u00a9t\u00c3\u0083\u00c2\u00a9 des Concerts du Conservatoire\/Andr\u00c3\u0083\u00c2\u00a9 Cluytens","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":28,"lastName":"Jones","length":375.19628,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Piano Concerto No. 2 in G minor Op. 22 (2006 Digital Remaster): III. Presto","status":200,"ts":1541791749796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Pixies","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":229.3024,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":434,"song":"Where Is My Mind?","status":200,"ts":1541791835796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"LCD Soundsystem","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":221.64853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":434,"song":"Drunk Girls","status":200,"ts":1541792064796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Phil Collins","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":29,"lastName":"Jones","length":204.19873,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Two Hearts","status":200,"ts":1541792124796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Strokes","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":30,"lastName":"Jones","length":218.56608,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Reptilia","status":200,"ts":1541792328796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":0,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":427,"song":null,"status":200,"ts":1541792399796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"4 Skins","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":1,"lastName":"Young","length":165.51138,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":427,"song":"Clockwork Skinhead","status":200,"ts":1541792407796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Kate Ryan","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":31,"lastName":"Jones","length":239.96036,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Scream For More","status":200,"ts":1541792546796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Hi-Tek","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":2,"lastName":"Young","length":153.67791,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":427,"song":"God's Plan","status":200,"ts":1541792572796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Deborah Harry","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":3,"lastName":"Young","length":257.41016,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":427,"song":"Kiss It Better","status":200,"ts":1541792725796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Octopus Project","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":32,"lastName":"Jones","length":250.95791,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"All Of The Champs That Ever Lived","status":200,"ts":1541792785796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Escape The Fate","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":33,"lastName":"Jones","length":217.28608,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Something","status":200,"ts":1541793035796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Charttraxx Karaoke","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":34,"lastName":"Jones","length":225.17506,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Fireflies","status":200,"ts":1541793252796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Placebo","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":35,"lastName":"Jones","length":241.52771,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"English Summer Rain","status":200,"ts":1541793477796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Frightened Rabbit","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":36,"lastName":"Jones","length":146.46812,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Man\/Bag Of Sand","status":200,"ts":1541793718796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Darius Rucker","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":37,"lastName":"Jones","length":181.81179,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Don't Think I Don't Think About It","status":200,"ts":1541793864796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":38,"lastName":"Jones","length":249.99138,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Everlong","status":200,"ts":1541794045796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":39,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Downgrade","registration":1541062818796.0,"sessionId":392,"song":null,"status":200,"ts":1541794119796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":40,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":392,"song":null,"status":200,"ts":1541794129796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":405,"song":null,"status":200,"ts":1541794184796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"White Denim","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":148.55791,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":405,"song":"Transparency","status":200,"ts":1541794290796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Meters","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":41,"lastName":"Jones","length":167.00036,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Jambalaya (On The Bayou)","status":200,"ts":1541794294796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Ron Carter","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":497.13587,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":405,"song":"I CAN'T GET STARTED","status":200,"ts":1541794438796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Rihanna","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":42,"lastName":"Jones","length":208.40444,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Te Amo","status":200,"ts":1541794461796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Bayside","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":43,"lastName":"Jones","length":156.29016,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Kellum (Album Version)","status":200,"ts":1541794669796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Mariah","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":44,"lastName":"Jones","length":432.19546,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"My All","status":200,"ts":1541794825796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"She & Him","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":185.15546,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":405,"song":"Change Is Hard","status":200,"ts":1541794935796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ladytron","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":325.14567,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":405,"song":"Sugar (Jagz Kooner Mix)","status":200,"ts":1541795120796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Soft","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":45,"lastName":"Jones","length":195.7873,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Dumb Blood","status":200,"ts":1541795257796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Format","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":46,"lastName":"Jones","length":241.10975,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Time Bomb","status":200,"ts":1541795452796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Michael Jackson","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":47,"lastName":"Jones","length":390.5824,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"In The Closet","status":200,"ts":1541795693796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"JLS","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":48,"lastName":"Jones","length":172.53832,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Don't Go","status":200,"ts":1541796083796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Young Money featuring Lloyd","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":49,"lastName":"Jones","length":196.33587,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"BedRock (Radio Edit) (feat.Lloyd)","status":200,"ts":1541796255796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Peter Tosh","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":50,"lastName":"Jones","length":320.02567,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Rock With Me","status":200,"ts":1541796451796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Nick Duffy","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":51,"lastName":"Jones","length":235.49342,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Motor Panir","status":200,"ts":1541796771796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Alanis Morissette","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":52,"lastName":"Jones","length":175.82975,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Right Through You (LP Version)","status":200,"ts":1541797006796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":53,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":392,"song":null,"status":200,"ts":1541797008796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Muse","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":54,"lastName":"Jones","length":209.50159,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Supermassive Black Hole (Twilight Soundtrack Version)","status":200,"ts":1541797181796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Bon Iver","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":55,"lastName":"Jones","length":242.93832,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Brackett_ WI","status":200,"ts":1541797390796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Leftover Crack","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":56,"lastName":"Jones","length":195.082,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Burn Them Prisons","status":200,"ts":1541797632796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"For Squirrels","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":57,"lastName":"Jones","length":337.162,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Mighty K.C.","status":200,"ts":1541797827796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Fobia","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":58,"lastName":"Jones","length":290.40281,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Tu Me Asustas","status":200,"ts":1541798164796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Indian Jewelry","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":59,"lastName":"Jones","length":295.83628,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Barbwire","status":200,"ts":1541798454796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"M.O.P.","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":60,"lastName":"Jones","length":232.6722,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Ante Up (Robbin Hoodz Theory)","status":200,"ts":1541798749796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Eminem \/ Dr. Dre \/ 50 Cent","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":61,"lastName":"Jones","length":297.482,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Crack A Bottle","status":200,"ts":1541798981796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Shakira","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":0,"lastName":"Williams","length":571.16689,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":311,"song":"Estoy Aqu\u00c3\u0083\u00c2\u00ad","status":200,"ts":1541799204796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Usher Featuring Lil' Jon & Ludacris","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":62,"lastName":"Jones","length":250.38322,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Yeah!","status":200,"ts":1541799278796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Rodrigo y Gabriela","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":63,"lastName":"Jones","length":223.16363,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Hanuman","status":200,"ts":1541799528796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Ramones","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":64,"lastName":"Jones","length":149.4722,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"I Wanna Be Sedated (Remastered Album Version )","status":200,"ts":1541799751796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Mayday Parade","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":65,"lastName":"Jones","length":316.9171,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":392,"song":"Miserable At Best (Album)","status":200,"ts":1541799900796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Eminem","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Graves","length":304.87465,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"Music Box","status":200,"ts":1541802473796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Cut Copy","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Graves","length":71.49669,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"Visions","status":200,"ts":1541802777796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Xandria","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Harris","length":216.81587,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":418,"song":"Calyx Virago","status":200,"ts":1541802783796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Missy Higgins","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Graves","length":274.80771,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"Drop The Mirror (EP Version)","status":200,"ts":1541802848796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Mobb Deep","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Harris","length":181.15873,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":418,"song":"Shook Ones pt. 2","status":200,"ts":1541802999796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Beatriz Luengo","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Graves","length":242.05016,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"Pretendo Hablarte","status":200,"ts":1541803122796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Evanescence","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":4,"lastName":"Graves","length":237.11302,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"Bring Me To Life","status":200,"ts":1541803364796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"OceanLab","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":5,"lastName":"Graves","length":440.842,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"Clear Blue Water","status":200,"ts":1541803601796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":239.3073,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":325,"song":"You're The One","status":200,"ts":1541803618796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Devil Wears Prada","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":205.66159,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":325,"song":"Lord Xenu","status":200,"ts":1541803857796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Eva Cassidy","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":6,"lastName":"Graves","length":248.86812,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"Take Me To The River","status":200,"ts":1541804041796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Mr. Oizo","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":7,"lastName":"Graves","length":325.22404,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"Flat Beat","status":200,"ts":1541804289796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Mariah Carey","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":8,"lastName":"Graves","length":261.642,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"Never Too Far","status":200,"ts":1541804614796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Kid Cudi Vs Crookers","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":9,"lastName":"Graves","length":162.97751,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"Day 'N' Nite","status":200,"ts":1541804875796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Pat Martino","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":10,"lastName":"Graves","length":355.94404,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"El Hombre","status":200,"ts":1541805037796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":11,"lastName":"Graves","length":218.40934,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"Geek In The Pink [Phil Tan Remix]","status":200,"ts":1541805392796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":12,"lastName":"Graves","length":239.3073,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"You're The One","status":200,"ts":1541805610796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Smokey Robinson & The Miracles","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":13,"lastName":"Graves","length":168.9073,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":297,"song":"I Second That Emotion","status":200,"ts":1541805849796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"}
475.342756
662
0.697145
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Hoobastank","auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":0,"lastName":"Finley","length":241.3971,"level":"free","location":"Richmond, VA","method":"PUT","page":"NextSong","registration":1541013292796.0,"sessionId":132,"song":"Say The Same","status":200,"ts":1541808927796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":"Mark Knopfler","auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":1,"lastName":"Finley","length":249.3122,"level":"free","location":"Richmond, VA","method":"PUT","page":"NextSong","registration":1541013292796.0,"sessionId":132,"song":"Why Aye Man","status":200,"ts":1541809168796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":"Mogwai","auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":2,"lastName":"Finley","length":341.28934,"level":"free","location":"Richmond, VA","method":"PUT","page":"NextSong","registration":1541013292796.0,"sessionId":132,"song":"We're No Here","status":200,"ts":1541809417796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":"The Casualties","auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":3,"lastName":"Finley","length":181.49832,"level":"free","location":"Richmond, VA","method":"PUT","page":"NextSong","registration":1541013292796.0,"sessionId":132,"song":"Punx Unite","status":200,"ts":1541809758796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":null,"auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":null,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1541032432796.0,"sessionId":424,"song":null,"status":200,"ts":1541813635796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"The Living End","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":188.62975,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":433,"song":"Roll On (Album Version)","status":200,"ts":1541822502796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Aloe Blacc","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":0,"lastName":"George","length":244.1922,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":402,"song":"I Need A Dollar","status":200,"ts":1541829709796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Faith No More","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":1,"lastName":"George","length":326.50404,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":402,"song":"Helpless","status":200,"ts":1541829953796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Chris Cornell","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":353.69751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Sunshower (Great Expectations Soundtrack)","status":200,"ts":1541835258796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Weezer","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":203.93751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"My Name Is Jonas","status":200,"ts":1541835611796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Stream of Passion feat. Ayreon","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":257.56689,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Valley Of The Queens","status":200,"ts":1541835814796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Lupe Fiasco","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":3,"lastName":"Kirby","length":273.94567,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Shining Down [feat. Matthew Santos] (Amended Album Version)","status":200,"ts":1541836071796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Tom Petty","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":4,"lastName":"Kirby","length":263.23546,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Runnin' Down A Dream","status":200,"ts":1541836344796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Killers","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":5,"lastName":"Kirby","length":220.89098,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"When You Were Young","status":200,"ts":1541836607796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Afghan Whigs","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":6,"lastName":"Kirby","length":179.40853,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"I'm Her Slave (Album)","status":200,"ts":1541836827796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"CSS","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":7,"lastName":"Kirby","length":213.75955,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Let's Make Love And Listen To Death From Above [Dan Carey Mix] (remastered album version)","status":200,"ts":1541837006796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Mos Def \/ Talib Kweli","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":8,"lastName":"Kirby","length":141.37424,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"History","status":200,"ts":1541837219796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Ryan Leslie","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":9,"lastName":"Kirby","length":203.96363,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"How It Was Supposed To Be","status":200,"ts":1541837360796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Mark Lowry","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":10,"lastName":"Kirby","length":168.28036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Get Together With The Lord (The Best Of Mark Lowry - Volume 2 Version)","status":200,"ts":1541837563796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Beirut","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":11,"lastName":"Kirby","length":230.19057,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Nantes","status":200,"ts":1541837731796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"MODESELEKTOR FEAT. PUPPETMASTAZ","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":12,"lastName":"Kirby","length":52.79302,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"THE DARK SIDE OF THE FROG","status":200,"ts":1541837961796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kid Cudi \/ Kanye West \/ Common","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":13,"lastName":"Kirby","length":237.76608,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Make Her Say","status":200,"ts":1541838013796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Julie Ruin","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":14,"lastName":"Kirby","length":142.47138,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Breakout A-Town","status":200,"ts":1541838250796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Sons And Daughters","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":15,"lastName":"Kirby","length":165.90322,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"The Bell","status":200,"ts":1541838392796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Children 18:3","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":16,"lastName":"Kirby","length":178.52036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Mock The Music","status":200,"ts":1541838557796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Chris Cagle","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":17,"lastName":"Kirby","length":232.85506,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Miss Me Baby","status":200,"ts":1541838735796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"John Waite","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":18,"lastName":"Kirby","length":269.76608,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Missing You","status":200,"ts":1541838967796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Basshunter","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":19,"lastName":"Kirby","length":223.32036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Walk On Water","status":200,"ts":1541839236796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Jay-Z \/ Lil Wayne","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":20,"lastName":"Kirby","length":236.01587,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Hello Brooklyn 2.0","status":200,"ts":1541839459796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Snow Patrol","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":21,"lastName":"Kirby","length":273.6322,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"It's Beginning To Get To Me","status":200,"ts":1541839695796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Coldcut","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":22,"lastName":"Kirby","length":203.07546,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Autumn Leaves","status":200,"ts":1541839968796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Magic Dirt","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":23,"lastName":"Kirby","length":251.79383,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Plastic Loveless Letter","status":200,"ts":1541840171796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"J. Karjalainen & Mustat Lasit","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":24,"lastName":"Kirby","length":336.74404,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Sinisten t\u00c3\u0083\u00c2\u00a4htien alla","status":200,"ts":1541840422796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":25,"lastName":"Kirby","length":224.67873,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Secrets","status":200,"ts":1541840758796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Nirvana","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":26,"lastName":"Kirby","length":219.08853,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Come As You Are","status":200,"ts":1541840982796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540306145796.0,"sessionId":359,"song":null,"status":200,"ts":1541841030796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Joyce Cooling","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":27,"lastName":"Kirby","length":248.11057,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"It's Time I Go (Jazz)","status":200,"ts":1541841201796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":28,"lastName":"Kirby","length":211.722,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Unite (2009 Digital Remaster)","status":200,"ts":1541841449796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Usher Featuring Lil' Jon & Ludacris","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":29,"lastName":"Kirby","length":250.38322,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Yeah!","status":200,"ts":1541841660796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Nelly \/ Paul Wall \/ Ali & Gipp","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":30,"lastName":"Kirby","length":272.50893,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Grillz","status":200,"ts":1541841910796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Audition","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":31,"lastName":"Kirby","length":207.20281,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"The Running Man","status":200,"ts":1541842182796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Savage Garden","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":32,"lastName":"Kirby","length":277.26322,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Truly Madly Deeply","status":200,"ts":1541842389796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Adam Green","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":33,"lastName":"Kirby","length":141.00853,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Festival Song","status":200,"ts":1541842666796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Tom Petty","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":34,"lastName":"Kirby","length":204.82567,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Square One (Album Version)","status":200,"ts":1541842807796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Muse","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":35,"lastName":"Kirby","length":209.34485,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":350,"song":"Supermassive Black Hole (Album Version)","status":200,"ts":1541843011796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Gerbils","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":27.01016,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":304,"song":"(iii)","status":200,"ts":1541843974796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Robert Plant","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":1,"lastName":"Hicks","length":265.66485,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":304,"song":"Dancing In Heaven (2006 Remastered LP Version)","status":200,"ts":1541844001796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Metallica","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":2,"lastName":"Hicks","length":387.02975,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":304,"song":"Welcome Home (Sanitarium)","status":200,"ts":1541844266796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Infected Mushroom","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":3,"lastName":"Hicks","length":506.51383,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":304,"song":"Deeply Disturbed","status":200,"ts":1541844653796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Eliza Doolittle","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":4,"lastName":"Hicks","length":184.60689,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":304,"song":"Rollerblades","status":200,"ts":1541845159796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Alvin And The Chipmunks","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":5,"lastName":"Hicks","length":162.63791,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":304,"song":"Ain't No Party","status":200,"ts":1541845343796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Chromeo","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":6,"lastName":"Hicks","length":348.65587,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":304,"song":"You're So Gangsta","status":200,"ts":1541845505796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Keisha White","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":251.42812,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":387,"song":"Brother","status":200,"ts":1541853599796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Juanes","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":1,"lastName":"Arellano","length":247.37914,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":387,"song":"Damelo","status":200,"ts":1541853850796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":null,"auth":"Logged In","firstName":"Walter","gender":"M","itemInSession":0,"lastName":"Frye","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540919166796.0,"sessionId":180,"song":null,"status":200,"ts":1541854061796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"39"} {"artist":"Karnivool","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":470.80444,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":445,"song":"Umbra","status":200,"ts":1541860418796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"WES","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":221.57016,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":444,"song":"Alane","status":200,"ts":1541861220796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Asia 2001","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":1,"lastName":"Owens","length":150.30812,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":444,"song":"Epilogue","status":200,"ts":1541861441796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Spike Milligan","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":220.39465,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":384,"song":"Nothing At All","status":200,"ts":1541862959796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Laura Izibor","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":211.56526,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":378,"song":"Carousel (PSILY Album Version)","status":200,"ts":1541867247796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":426,"song":null,"status":200,"ts":1541870196796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Ryan Adams","auth":"Logged In","firstName":"Braden","gender":"M","itemInSession":0,"lastName":"Parker","length":248.5024,"level":"free","location":"Youngstown-Warren-Boardman, OH-PA","method":"PUT","page":"NextSong","registration":1540999292796.0,"sessionId":246,"song":"Wonderwall","status":200,"ts":1541871116796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"74"} {"artist":null,"auth":"Logged In","firstName":"Adelyn","gender":"F","itemInSession":0,"lastName":"Jordan","length":null,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1540130971796.0,"sessionId":391,"song":null,"status":200,"ts":1541871867796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"7"} {"artist":"Method Man","auth":"Logged In","firstName":"Adelyn","gender":"F","itemInSession":1,"lastName":"Jordan","length":204.64281,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1540130971796.0,"sessionId":391,"song":"The Motto","status":200,"ts":1541871869796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"7"} {"artist":"The Stanley Brothers","auth":"Logged In","firstName":"Adelyn","gender":"F","itemInSession":2,"lastName":"Jordan","length":179.69587,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1540130971796.0,"sessionId":391,"song":"I'm A Man Of Constant Sorrow","status":200,"ts":1541872073796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"7"} {"artist":"Dexter Freebish","auth":"Logged In","firstName":"Adelyn","gender":"F","itemInSession":3,"lastName":"Jordan","length":210.54649,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1540130971796.0,"sessionId":391,"song":"Deeper","status":200,"ts":1541872252796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"7"} {"artist":"Jamiroquai","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":0,"lastName":"Rogers","length":362.05669,"level":"free","location":"San Diego-Carlsbad, CA","method":"PUT","page":"NextSong","registration":1540976199796.0,"sessionId":432,"song":"Talullah","status":200,"ts":1541873727796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_2) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"18"} {"artist":"Michael Cera & Ellen Page","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":0,"lastName":"Jones","length":116.71465,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Anyone Else But You","status":200,"ts":1541876932796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Cat Empire","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":1,"lastName":"Jones","length":218.22649,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"How To Explain","status":200,"ts":1541877048796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Bryn Terfel \/ Berliner Philharmoniker \/ Claudio Abbado","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":2,"lastName":"Jones","length":967.36608,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Wotan's Farewell & Magic Fire Music","status":200,"ts":1541877266796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Fugees","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":3,"lastName":"Jones","length":281.20771,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Ready Or Not","status":200,"ts":1541878233796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Hardline","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":4,"lastName":"Jones","length":234.73587,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Everything","status":200,"ts":1541878514796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Funky Lowlives","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":5,"lastName":"Jones","length":280.34567,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Sail Into the Sun","status":200,"ts":1541878748796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"DL Incognito","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":6,"lastName":"Jones","length":221.07383,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Proof","status":200,"ts":1541879028796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540306145796.0,"sessionId":447,"song":null,"status":200,"ts":1541879108796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Justice","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":7,"lastName":"Jones","length":243.40853,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"TTHHEE PPAARRTTYY","status":200,"ts":1541879249796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Earth_ Wind & Fire","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Smith","length":178.20689,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":447,"song":"Night Dreamin'","status":200,"ts":1541879270796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Strawbs","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":8,"lastName":"Jones","length":255.81669,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Sheep","status":200,"ts":1541879492796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Angus & Julia Stone","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":9,"lastName":"Jones","length":172.85179,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Wasted","status":200,"ts":1541879747796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Sara Bareilles","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":10,"lastName":"Jones","length":260.8322,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Love Song","status":200,"ts":1541879919796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Bruna Caram","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":11,"lastName":"Jones","length":198.63465,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Meus Sonhos","status":200,"ts":1541880179796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Nando Reis","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":12,"lastName":"Jones","length":239.82975,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"O Segundo Sol","status":200,"ts":1541880377796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":13,"lastName":"Jones","length":189.28281,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Same Old Thing","status":200,"ts":1541880616796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Kreator","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":14,"lastName":"Jones","length":294.53016,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Riot Of Violence","status":200,"ts":1541880805796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Audioslave","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":15,"lastName":"Jones","length":277.83791,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Show Me How To Live","status":200,"ts":1541881099796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Red Hot Chili Peppers","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":16,"lastName":"Jones","length":269.34812,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Parallel Universe (Album Version)","status":200,"ts":1541881376796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Manu Chao","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":17,"lastName":"Jones","length":288.15628,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Me Quedo Contigo [Si Me Das A Elegir]","status":200,"ts":1541881645796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":18,"lastName":"Jones","length":277.15873,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1541881933796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Ron Carter","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":19,"lastName":"Jones","length":497.13587,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":439,"song":"I CAN'T GET STARTED","status":200,"ts":1541882210796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Harris","length":null,"level":"free","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1541097374796.0,"sessionId":440,"song":null,"status":200,"ts":1541884206796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Harris","length":null,"level":"free","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1541097374796.0,"sessionId":440,"song":null,"status":200,"ts":1541884572796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Lifehouse","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":2,"lastName":"Harris","length":195.47383,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":440,"song":"You And Me (Wedding Version)","status":200,"ts":1541884618796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Yann Tiersen","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":0,"lastName":"Summers","length":158.71955,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":333,"song":"La Valse D'Am\u00c3\u0083\u00c2\u00a9lie (Version Piano)","status":200,"ts":1541885952796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"ISRAEL & NEW BREED","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":1,"lastName":"Summers","length":176.48281,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":333,"song":"Awesome Medley","status":200,"ts":1541886110796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":null,"auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":0,"lastName":"Taylor","length":null,"level":"free","location":"St. Louis, MO-IL","method":"GET","page":"Home","registration":1540992766796.0,"sessionId":396,"song":null,"status":200,"ts":1541886726796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"Stellar Kart","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":1,"lastName":"Taylor","length":186.17424,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":396,"song":"Jesus Loves You (Album Version)","status":200,"ts":1541886750796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"}
458.135417
574
0.696796
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Frumpies","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":134.47791,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":455,"song":"Fuck Kitty","status":200,"ts":1541903636796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Kenny G with Peabo Bryson","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":1,"lastName":"Simpson","length":264.75057,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":455,"song":"By The Time This Night Is Over","status":200,"ts":1541903770796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Biffy Clyro","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":2,"lastName":"Simpson","length":189.83138,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":455,"song":"God & Satan","status":200,"ts":1541904034796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":456,"song":null,"status":200,"ts":1541910841796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"HIM","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":212.06159,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":456,"song":"Beautiful","status":200,"ts":1541910973796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Matmos","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":0,"lastName":"Gutierrez","length":1449.11628,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":284,"song":"Supreme Balloon","status":200,"ts":1541911006796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Gary Allan","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":0,"lastName":"Smith","length":259.83955,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":328,"song":"The One","status":200,"ts":1541930188796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Miracle Fortress","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":1,"lastName":"Smith","length":200.9073,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":328,"song":"Five Roses","status":200,"ts":1541930447796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Don Omar","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":2,"lastName":"Smith","length":261.35465,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":328,"song":"Cuentale","status":200,"ts":1541930647796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Jay-Z","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":3,"lastName":"Smith","length":212.27057,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":328,"song":"D'Evils","status":200,"ts":1541930908796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Red Hot Chili Peppers","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":4,"lastName":"Smith","length":231.33995,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":328,"song":"Easily (Album Version)","status":200,"ts":1541931120796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":437,"song":null,"status":200,"ts":1541932052796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Flogging Molly","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":361.9522,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":437,"song":"Rebels of the Sacred Heart","status":200,"ts":1541932063796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Reverend Horton Heat","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":158.64118,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":437,"song":"Now_ Right Now","status":200,"ts":1541932424796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sea Wolf","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":232.61995,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":437,"song":"I Made A Resolution","status":200,"ts":1541932582796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jason Mraz & Colbie Caillat","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":189.6224,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":437,"song":"Lucky (Album Version)","status":200,"ts":1541932814796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jamie Lidell","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":175.25506,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":437,"song":"Enough\u0019s Enough","status":200,"ts":1541933003796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Feist","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":212.79302,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":437,"song":"Mushaboom (Postal Service Mix)","status":200,"ts":1541933178796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"Logout","registration":1540940782796.0,"sessionId":437,"song":null,"status":307,"ts":1541933179796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":8,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":437,"song":null,"status":200,"ts":1541933298796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":9,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":437,"song":null,"status":200,"ts":1541934031796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":10,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":437,"song":null,"status":307,"ts":1541934032796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":437,"song":null,"status":200,"ts":1541934168796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sex Slaves","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":175.51628,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":437,"song":"We're Going Out Tonight","status":200,"ts":1541934891796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":469,"song":null,"status":200,"ts":1541943439796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Rise Against","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":169.482,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":469,"song":"To Them These Streets Belong","status":200,"ts":1541943682796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":441,"song":null,"status":200,"ts":1541944080796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":359.54893,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":441,"song":"Get Me Bodied","status":200,"ts":1541944343796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Nate Dogg","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":356.38812,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":441,"song":"Never Leave Me Alone","status":200,"ts":1541944702796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":0,"lastName":"Finley","length":null,"level":"free","location":"Richmond, VA","method":"GET","page":"Home","registration":1541013292796.0,"sessionId":443,"song":null,"status":200,"ts":1541945130796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":1,"lastName":"Finley","length":233.89995,"level":"free","location":"Richmond, VA","method":"PUT","page":"NextSong","registration":1541013292796.0,"sessionId":443,"song":"Love Story","status":200,"ts":1541945143796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":"Lynyrd Skynyrd","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":216.60689,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":452,"song":"Sweet home Alabama","status":200,"ts":1541945274796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Kelis","auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":2,"lastName":"Finley","length":293.58975,"level":"free","location":"Richmond, VA","method":"PUT","page":"NextSong","registration":1541013292796.0,"sessionId":443,"song":"Caught Out There (Explicit)","status":200,"ts":1541945376796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":"The Kills","auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":3,"lastName":"Finley","length":203.38893,"level":"free","location":"Richmond, VA","method":"PUT","page":"NextSong","registration":1541013292796.0,"sessionId":443,"song":"Last Day Of Magic","status":200,"ts":1541945669796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":448,"song":null,"status":200,"ts":1541945702796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Collie Buddz featuring Paul Wall","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":271.62077,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":448,"song":"What A Feeling","status":200,"ts":1541945706796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Charttraxx Karaoke","auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":4,"lastName":"Finley","length":225.17506,"level":"free","location":"Richmond, VA","method":"PUT","page":"NextSong","registration":1541013292796.0,"sessionId":443,"song":"Fireflies","status":200,"ts":1541945872796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":"Band Of Horses","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":321.14893,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":448,"song":"The Funeral (Album Version)","status":200,"ts":1541945977796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Coldplay","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":3,"lastName":"Kirby","length":307.51302,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":448,"song":"Clocks","status":200,"ts":1541946298796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Bon Jovi","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":4,"lastName":"Kirby","length":228.75383,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":448,"song":"Have A Nice Day","status":200,"ts":1541946605796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"P.O.D.","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":5,"lastName":"Kirby","length":203.7024,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":448,"song":"Alive (2006 Remastered Album Version)","status":200,"ts":1541946833796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Bloc Party","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":6,"lastName":"Kirby","length":222.04036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":448,"song":"Plans (Replanned by Mogwai)","status":200,"ts":1541947036796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Los Prisioneros","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":7,"lastName":"Kirby","length":211.12118,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":448,"song":"Pa Pa Pa","status":200,"ts":1541947258796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Octopus Project","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":8,"lastName":"Kirby","length":175.25506,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":448,"song":"Lots More Stairs","status":200,"ts":1541947469796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Roudoudou","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":9,"lastName":"Kirby","length":18.41587,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":448,"song":"Ecoute Ce Scratch","status":200,"ts":1541947644796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Africando","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":10,"lastName":"Kirby","length":253.54404,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":448,"song":"Tierra Tradicional","status":200,"ts":1541947662796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"RUN-DMC Featuring Method Man_ Kenny Cash_ Mike Ransom_ and Jamel Simmons","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":11,"lastName":"Kirby","length":266.52689,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":448,"song":"Simmons Incorporated","status":200,"ts":1541947915796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":0,"lastName":"Santana","length":null,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"GET","page":"Home","registration":1540856629796.0,"sessionId":414,"song":null,"status":200,"ts":1541948035796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Graham Coxon","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":1,"lastName":"Santana","length":197.14567,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":414,"song":"I'm Goin' Away","status":200,"ts":1541948047796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Queens Of The Stone Age","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":12,"lastName":"Kirby","length":231.02649,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":448,"song":"In The Fade","status":200,"ts":1541948181796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Dance Gavin Dance","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":2,"lastName":"Santana","length":193.30567,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":414,"song":"Strawberry Andr\u00c3\u0083\u00c2\u00a9 (Album Version)","status":200,"ts":1541948244796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":null,"auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":3,"lastName":"Santana","length":null,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"GET","page":"Home","registration":1540856629796.0,"sessionId":414,"song":null,"status":200,"ts":1541948258796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Passion Pit","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":13,"lastName":"Kirby","length":243.69587,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":448,"song":"Eyes As Candles","status":200,"ts":1541948412796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":14,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":448,"song":null,"status":200,"ts":1541948426796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":4,"lastName":"Santana","length":229.61587,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":414,"song":"Let's Get It Started","status":200,"ts":1541948437796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Plastic Bertrand","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":5,"lastName":"Santana","length":180.00934,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":414,"song":"Ca plane pour moi","status":200,"ts":1541948666796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Cream","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":6,"lastName":"Santana","length":166.5824,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":414,"song":"Strange Brew","status":200,"ts":1541948846796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Coldplay","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":7,"lastName":"Santana","length":284.39465,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":414,"song":"A Message","status":200,"ts":1541949012796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Cute Is What We Aim For","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":8,"lastName":"Santana","length":172.22485,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":414,"song":"Sweat the Battle Before the Battle Sweats You (Album Version)","status":200,"ts":1541949296796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Metallica","auth":"Logged In","firstName":"Connar","gender":"M","itemInSession":0,"lastName":"Moreno","length":256.9922,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540823606796.0,"sessionId":218,"song":"Of Wolf And Man","status":200,"ts":1541952079796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10) AppleWebKit\/538.46 (KHTML, like Gecko) Version\/8.0 Safari\/538.46\"","userId":"62"} {"artist":"The Kills","auth":"Logged In","firstName":"Connar","gender":"M","itemInSession":1,"lastName":"Moreno","length":217.70404,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540823606796.0,"sessionId":218,"song":"Tape Song","status":200,"ts":1541952335796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10) AppleWebKit\/538.46 (KHTML, like Gecko) Version\/8.0 Safari\/538.46\"","userId":"62"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Connar","gender":"M","itemInSession":2,"lastName":"Moreno","length":271.38567,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540823606796.0,"sessionId":218,"song":"The Pretender","status":200,"ts":1541952552796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10) AppleWebKit\/538.46 (KHTML, like Gecko) Version\/8.0 Safari\/538.46\"","userId":"62"} {"artist":"Plaid","auth":"Logged In","firstName":"Connar","gender":"M","itemInSession":3,"lastName":"Moreno","length":260.96281,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540823606796.0,"sessionId":218,"song":"Eyen [Chosen by fans on Warp20.net]","status":200,"ts":1541952823796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10) AppleWebKit\/538.46 (KHTML, like Gecko) Version\/8.0 Safari\/538.46\"","userId":"62"} {"artist":null,"auth":"Logged In","firstName":"Brayden","gender":"M","itemInSession":0,"lastName":"Clark","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1541029236796.0,"sessionId":120,"song":null,"status":200,"ts":1541954601796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"41"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Harris","length":null,"level":"free","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1541097374796.0,"sessionId":462,"song":null,"status":200,"ts":1541959679796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"The Van Pelt","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Harris","length":208.71791,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":462,"song":"It's New To Me","status":200,"ts":1541959713796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":472,"song":null,"status":200,"ts":1541962018796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"+44","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":224.57424,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":472,"song":"Make You Smile","status":200,"ts":1541962092796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":0,"lastName":"George","length":null,"level":"free","location":"Birmingham-Hoover, AL","method":"GET","page":"Home","registration":1541020249796.0,"sessionId":446,"song":null,"status":200,"ts":1541962134796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Chris Brown","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":1,"lastName":"George","length":275.1473,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":446,"song":"I May Never Find","status":200,"ts":1541962141796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"KT Tunstall","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":170.47465,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":472,"song":"Black Horse And The Cherry Tree (Radio Version)","status":200,"ts":1541962316796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Cascada","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":2,"lastName":"George","length":184.39791,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":446,"song":"Kids In America","status":200,"ts":1541962416796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Incubus","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":3,"lastName":"Smith","length":293.38077,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":472,"song":"Black Heart Inertia","status":200,"ts":1541962486796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":4,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Help","registration":1541016707796.0,"sessionId":472,"song":null,"status":200,"ts":1541962633796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":5,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":472,"song":null,"status":200,"ts":1541962656796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":435,"song":null,"status":200,"ts":1541965304796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Miike Snow","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":220.83873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":435,"song":"Black & Blue","status":200,"ts":1541965305796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Cartola","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":208.92689,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":435,"song":"Sala De Recep\u00c3\u0083\u00c2\u00a7\u00c3\u0083\u00c2\u00a3o","status":200,"ts":1541965525796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kill The Client","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":70.68689,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":435,"song":"Commander In Thief","status":200,"ts":1541965733796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":435,"song":null,"status":200,"ts":1541965947796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Wolfmother","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":175.82975,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":435,"song":"Woman","status":200,"ts":1541966183796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Old Crow Medicine Show","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":231.73179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":435,"song":"Wagon Wheel","status":200,"ts":1541966358796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Architecture In Helsinki","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":173.73995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":435,"song":"Debbie","status":200,"ts":1541966589796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Charlie Louvin","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":170.86649,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":435,"song":"I Think I'll Live","status":200,"ts":1541966762796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Miguel Morales","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":270.78485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":435,"song":"La Derrota de Un Don Juan","status":200,"ts":1541966932796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Dominique A","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":153.20771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":435,"song":"Le Courage Des Oiseaux","status":200,"ts":1541967202796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Cock Sparrer","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":203.25832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":435,"song":"Run With The Blind","status":200,"ts":1541967355796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jimmy Wakely","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":165.74649,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":435,"song":"I Love You So Much It Hurts","status":200,"ts":1541967558796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Peter Doherty","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":217.02485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":435,"song":"A Little Death Around the Eyes","status":200,"ts":1541967723796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Katy Perry","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":246.41261,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":435,"song":"Thinking Of You","status":200,"ts":1541967940796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Sidewalk Prophets","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":0,"lastName":"Taylor","length":260.62322,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":464,"song":"You Love Me Anyway (Album)","status":200,"ts":1541970568796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"Rise Against","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":1,"lastName":"Taylor","length":221.17832,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":464,"song":"Torches","status":200,"ts":1541970828796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"K'Naan","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":2,"lastName":"Taylor","length":220.49914,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":464,"song":"Wavin' Flag","status":200,"ts":1541971049796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"Patrick Jumpen","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":208.87465,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":480,"song":"Holiday","status":200,"ts":1541979540796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Alicia Keys","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":216.47628,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":480,"song":"Empire State Of Mind (Part II) Broken Down","status":200,"ts":1541979748796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"}
459.126316
560
0.698543
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":null,"auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":0,"lastName":"Williams","length":null,"level":"free","location":"Klamath Falls, OR","method":"GET","page":"Home","registration":1541077528796.0,"sessionId":438,"song":null,"status":200,"ts":1541990217796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Pavement","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":99.16036,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":345,"song":"Mercy:The Laundromat","status":200,"ts":1541990258796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":1,"lastName":"Williams","length":277.15873,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":438,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1541990264796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Gary Allan","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":2,"lastName":"Williams","length":211.22567,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":438,"song":"Nothing On But The Radio","status":200,"ts":1541990541796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":0,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":389,"song":null,"status":200,"ts":1541990714796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Charttraxx Karaoke","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":3,"lastName":"Williams","length":225.17506,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":438,"song":"Fireflies","status":200,"ts":1541990752796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"The Libertines","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":1,"lastName":"Lynch","length":179.53914,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":389,"song":"The Good Old Days","status":200,"ts":1541990842796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Huey Lewis And The News","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":2,"lastName":"Lynch","length":245.52444,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":389,"song":"Hip To Be Square","status":200,"ts":1541991021796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"JOSEF LOCKE & ORCHESTRA","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":3,"lastName":"Lynch","length":166.26893,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":389,"song":"How Can You Buy Killarney (1992 Digital Remaster)","status":200,"ts":1541991266796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Train","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":4,"lastName":"Lynch","length":216.76363,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":389,"song":"Hey_ Soul Sister","status":200,"ts":1541991432796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Blind Pilot","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":5,"lastName":"Lynch","length":156.94322,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":389,"song":"I Buried a Bone","status":200,"ts":1541991648796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Anjulie","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":6,"lastName":"Lynch","length":194.63791,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":389,"song":"Boom","status":200,"ts":1541991804796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"59 Times the Pain","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Rodriguez","length":144.95302,"level":"free","location":"Los Angeles-Long Beach-Anaheim, CA","method":"PUT","page":"NextSong","registration":1540992715796.0,"sessionId":136,"song":"Found Home","status":200,"ts":1541993788796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"68"} {"artist":null,"auth":"Logged In","firstName":"Kimber","gender":"F","itemInSession":0,"lastName":"Norris","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540975589796.0,"sessionId":412,"song":null,"status":200,"ts":1542000167796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"47"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"About","registration":1540621059796.0,"sessionId":466,"song":null,"status":200,"ts":1542001320796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":466,"song":null,"status":200,"ts":1542001337796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":470,"song":null,"status":200,"ts":1542001991796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":483,"song":null,"status":200,"ts":1542002972796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Pork Dukes","auth":"Logged In","firstName":"Noah","gender":"M","itemInSession":0,"lastName":"Chavez","length":133.04118,"level":"free","location":"Ogden-Clearfield, UT","method":"PUT","page":"NextSong","registration":1540970748796.0,"sessionId":262,"song":"Bend & Flush","status":200,"ts":1542003207796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"94"} {"artist":null,"auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":0,"lastName":"Barrera","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540835983796.0,"sessionId":428,"song":null,"status":200,"ts":1542012631796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Plan B","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":1,"lastName":"Barrera","length":254.95465,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":428,"song":"Traded In My Cigarettes","status":200,"ts":1542012644796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Rell featuring Dert_ Killa Klump_ Silence","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":2,"lastName":"Barrera","length":223.97342,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":428,"song":"Talk Is Drastik","status":200,"ts":1542012898796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"K-OS","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":3,"lastName":"Barrera","length":211.33016,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":428,"song":"EMCEE Murdah","status":200,"ts":1542013121796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Vanessa Carlton","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":4,"lastName":"Barrera","length":272.40444,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":428,"song":"Come Undone","status":200,"ts":1542013332796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Camila","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":0,"lastName":"Benson","length":280.34567,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":377,"song":"De Mi","status":200,"ts":1542013383796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Buju Banton","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":1,"lastName":"Benson","length":232.48934,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":377,"song":"Cry No More","status":200,"ts":1542013663796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":490,"song":null,"status":200,"ts":1542017836796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Feist","auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":0,"lastName":"Ayala","length":184.94649,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"PUT","page":"NextSong","registration":1541007976796.0,"sessionId":318,"song":"My Moon My Man","status":200,"ts":1542017923796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":201.79546,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":490,"song":"Revelry","status":200,"ts":1542018073796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Beck","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":228.80608,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":344,"song":"Lost Cause","status":200,"ts":1542018366796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Big Walter Horton's Blues Harp Band","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":210.78159,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":344,"song":"Rockin' My Boogie","status":200,"ts":1542018594796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Supervielle","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":2,"lastName":"Hess","length":263.83628,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":344,"song":"332","status":200,"ts":1542018804796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Bryan Adams","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":254.79791,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":454,"song":"Cloud Number Nine","status":200,"ts":1542018902796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Slipknot","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":3,"lastName":"Hess","length":259.44771,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":344,"song":"Eyeless (Live version) (Album Version)","status":200,"ts":1542019067796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":4,"lastName":"Hess","length":139.51955,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":344,"song":"I'll Be Your Man","status":200,"ts":1542019326796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Shinedown","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":233.97832,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":449,"song":"Sound Of Madness (Album Version)","status":200,"ts":1542021588796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Devin Townsend","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":576.33914,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":450,"song":"Earth Day","status":200,"ts":1542022869796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":1,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"Logout","registration":1540006905796.0,"sessionId":450,"song":null,"status":307,"ts":1542022870796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":450,"song":null,"status":200,"ts":1542022878796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":450,"song":null,"status":307,"ts":1542022879796,"userAgent":null,"userId":""} {"artist":"Stray Cats","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":243.77424,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":491,"song":"Jeanie Jeanie Jeanie","status":200,"ts":1542022882796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":4,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"GET","page":"Home","registration":1540006905796.0,"sessionId":450,"song":null,"status":200,"ts":1542022981796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":239.3073,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":491,"song":"You're The One","status":200,"ts":1542023125796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"Logout","registration":1541016707796.0,"sessionId":491,"song":null,"status":307,"ts":1542023126796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":491,"song":null,"status":200,"ts":1542023240796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"About","registration":null,"sessionId":491,"song":null,"status":200,"ts":1542023278796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":5,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"GET","page":"Upgrade","registration":1540006905796.0,"sessionId":450,"song":null,"status":200,"ts":1542023402796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Talking Heads","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":6,"lastName":"Arellano","length":259.02975,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":450,"song":"Road To Nowhere (Remastered LP Version )","status":200,"ts":1542023445796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":7,"lastName":"Arellano","length":406.17751,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":450,"song":"Paradise City","status":200,"ts":1542023704796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":0,"lastName":"Burke","length":195.13424,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":316,"song":"Smile (Explicit Version)","status":200,"ts":1542031368796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"LCD Soundsystem","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":1,"lastName":"Burke","length":201.56036,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":316,"song":"Daft Punk Is Playing At My House","status":200,"ts":1542031563796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"Tiefschwarz","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":2,"lastName":"Burke","length":455.78404,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":316,"song":"Wait & See (Gucci Soundsystem Remix)","status":200,"ts":1542031764796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"Buckcherry","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":263.36608,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":489,"song":"Everything (Album Version)","status":200,"ts":1542032149796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"The Get Up Kids","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":3,"lastName":"Burke","length":205.26975,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":316,"song":"Forgive and Forget","status":200,"ts":1542032219796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"Neko Case","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":151.01342,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":489,"song":"People Got A Lotta Nerve","status":200,"ts":1542032412796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Outkast Featuring Killer Mike","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":4,"lastName":"Burke","length":295.33995,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":316,"song":"The Whole World","status":200,"ts":1542032424796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"Does It Offend You_ Yeah?","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Burns","length":220.57751,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":489,"song":"Doomed Now","status":200,"ts":1542032563796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Eminem","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":5,"lastName":"Burke","length":268.5122,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":316,"song":"My Name Is","status":200,"ts":1542032719796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"Kabosh","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Burns","length":242.41587,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":489,"song":"Little Pills","status":200,"ts":1542032783796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Enigma","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":6,"lastName":"Burke","length":141.5571,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":316,"song":"The Voice Of Enigma","status":200,"ts":1542032987796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Burns","length":226.53342,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":489,"song":"After An Afternoon (Eagles Ballroom Live Version)","status":200,"ts":1542033025796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":null,"auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540492941796.0,"sessionId":497,"song":null,"status":200,"ts":1542034998796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":1,"lastName":"Gonzalez","length":234.26567,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":497,"song":"The Desperate Man","status":200,"ts":1542035050796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Mayday Parade","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":2,"lastName":"Gonzalez","length":290.79465,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":497,"song":"Three Cheers for Five Years (Acoustic)","status":200,"ts":1542035284796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Sam Cooke","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":3,"lastName":"Gonzalez","length":122.04363,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":497,"song":"Ain't Misbehavin","status":200,"ts":1542035574796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":496,"song":null,"status":200,"ts":1542037333796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":496,"song":null,"status":200,"ts":1542037696796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":374,"song":null,"status":307,"ts":1542037774796,"userAgent":null,"userId":""} {"artist":"Enrique Iglesias","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":241.42322,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":496,"song":"Tired Of Being Sorry","status":200,"ts":1542037810796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":374,"song":null,"status":200,"ts":1542037813796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Plain White T's","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":232.202,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":374,"song":"Hey There Delilah","status":200,"ts":1542037901796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":503,"song":null,"status":200,"ts":1542038013796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"The Brecker Brothers","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":217.5473,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":503,"song":"East River","status":200,"ts":1542038022796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Buckcherry","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":226.14159,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":496,"song":"Sorry (Album Version)","status":200,"ts":1542038051796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dayglo Abortions","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":142.78485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":374,"song":"Courage In A Can","status":200,"ts":1542038133796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Herbaliser","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":273.8673,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":374,"song":"Sensual Woman","status":200,"ts":1542038275796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Toni Braxton","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":268.45995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":374,"song":"Un-Break My Heart","status":200,"ts":1542038548796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Shania Twain","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":250.51383,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":374,"song":"Nah!","status":200,"ts":1542038816796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Discovery","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Roth","length":206.0273,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":247,"song":"I Want You Back","status":200,"ts":1542038818796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Roth","length":220.89098,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":247,"song":"Somebody To Love","status":200,"ts":1542039024796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":"Young Dro featuring T.I.","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":322.11546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":374,"song":"My Girl (Featuring T.I.) (Amended Album Version)","status":200,"ts":1542039066796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Rancid","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Roth","length":152.76363,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":247,"song":"Hooligans (Album Version)","status":200,"ts":1542039244796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":"Sergio Contreras","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":234.00444,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":374,"song":"D\u00c3\u0083\u00c2\u00adselo Con Arte","status":200,"ts":1542039388796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Jason Derulo","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":222.61506,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":374,"song":"Whatcha Say","status":200,"ts":1542039622796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"A Perfect Circle","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":246.04689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":374,"song":"The Outsider","status":200,"ts":1542039844796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Terrorvision","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":160.54812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":374,"song":"Glad All Over","status":200,"ts":1542040090796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":0,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Home","registration":1540558108796.0,"sessionId":294,"song":null,"status":200,"ts":1542040643796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Sufjan Stevens","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":1,"lastName":"Klein","length":179.04281,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"All The Kings Horns","status":200,"ts":1542040784796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Pieces Of A Dream","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":2,"lastName":"Klein","length":315.79383,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Ocean View","status":200,"ts":1542040963796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":3,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Home","registration":1540558108796.0,"sessionId":294,"song":null,"status":200,"ts":1542041116796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Alceu Valen\u00c3\u0083\u00c2\u00a7a","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":4,"lastName":"Klein","length":177.21424,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"No Balan\u00c3\u0083\u00c2\u00a7o Da Canoa","status":200,"ts":1542041278796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"George Younce","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":5,"lastName":"Klein","length":191.68608,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"This Old House w\/ When The Saints Medley","status":200,"ts":1542041455796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Miike Snow","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":6,"lastName":"Klein","length":385.35791,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Silvia","status":200,"ts":1542041646796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Vikki Carr","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":7,"lastName":"Klein","length":157.09995,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Cross Your Heart","status":200,"ts":1542042031796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Jorgen Ingmann","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":8,"lastName":"Klein","length":157.23057,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Oh! (LP Version)","status":200,"ts":1542042188796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"A.B. Quintanilla III Y Los Kumbia Kings","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":9,"lastName":"Klein","length":226.71628,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Pachuco","status":200,"ts":1542042345796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":75,"song":null,"status":307,"ts":1542042456796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":1,"lastName":"Duffy","length":null,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"GET","page":"Home","registration":1540146037796.0,"sessionId":75,"song":null,"status":200,"ts":1542042467796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Fatboy Slim","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":2,"lastName":"Duffy","length":192.9922,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":75,"song":"Illuminati","status":200,"ts":1542042467796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":10,"lastName":"Klein","length":214.67383,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"One Time","status":200,"ts":1542042571796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Metallica","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":11,"lastName":"Klein","length":515.21261,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Master Of Puppets","status":200,"ts":1542042785796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Freddie Mercury","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":12,"lastName":"Klein","length":219.29751,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"I Was Born To Love You (2000 Digital Remaster)","status":200,"ts":1542043300796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Angus & Julia Stone","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":0,"lastName":"Burke","length":262.42567,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":502,"song":"Jewels And Gold","status":200,"ts":1542043483796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"Max Richter","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":13,"lastName":"Klein","length":78.47138,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Vladimir's Blues","status":200,"ts":1542043519796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Angie Stone","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":14,"lastName":"Klein","length":269.37424,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Wish I Didn't Miss You","status":200,"ts":1542043597796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Small Black","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":15,"lastName":"Klein","length":237.89669,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Weird Machines","status":200,"ts":1542043866796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Collective Soul","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":16,"lastName":"Klein","length":218.40934,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Why Pt. 2","status":200,"ts":1542044103796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Feist","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":17,"lastName":"Klein","length":295.54893,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"My moon my man (Grizzy Bear Remix)","status":200,"ts":1542044321796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Roth","length":null,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"GET","page":"Home","registration":1540699429796.0,"sessionId":507,"song":null,"status":200,"ts":1542044364796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Roth","length":233.89995,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":507,"song":"Love Story","status":200,"ts":1542044382796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":505,"song":null,"status":200,"ts":1542044483796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Louis Smith","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":518.81751,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":505,"song":"South Side (Digitally Remastered)","status":200,"ts":1542044495796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Britney Spears","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":18,"lastName":"Klein","length":198.97424,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Toxic","status":200,"ts":1542044616796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Nelly \/ Jaheim","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":19,"lastName":"Klein","length":336.56118,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"My Place","status":200,"ts":1542044814796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Sisqo","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Burns","length":253.49179,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":505,"song":"Thong Song","status":200,"ts":1542045013796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"M\u00c3\u0083\u00c2\u00bam","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":20,"lastName":"Klein","length":175.59465,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Faraway Swimming Pool","status":200,"ts":1542045150796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Cass McCombs","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":21,"lastName":"Klein","length":234.13506,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Deseret","status":200,"ts":1542045325796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Poets Of Rhythm","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":22,"lastName":"Klein","length":252.05506,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"More Mess On My Thing","status":200,"ts":1542045559796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Lynyrd Skynyrd","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":23,"lastName":"Klein","length":233.29914,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"The Needle And The Spoon","status":200,"ts":1542045811796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":0,"lastName":"Harris","length":null,"level":"free","location":"Eugene, OR","method":"GET","page":"Home","registration":1540906915796.0,"sessionId":399,"song":null,"status":200,"ts":1542045924796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Radiohead","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":24,"lastName":"Klein","length":235.7024,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Creep (Explicit)","status":200,"ts":1542046044796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Train","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":1,"lastName":"Harris","length":239.04608,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":399,"song":"If It's Love","status":200,"ts":1542046045796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Incubus","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":25,"lastName":"Klein","length":232.46322,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Drive","status":200,"ts":1542046279796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":2,"lastName":"Harris","length":null,"level":"free","location":"Eugene, OR","method":"GET","page":"Error","registration":1540906915796.0,"sessionId":399,"song":null,"status":404,"ts":1542046363796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Rilo Kiley","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":26,"lastName":"Klein","length":270.99383,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"I Never (Album Version)","status":200,"ts":1542046511796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Nick Drake","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":27,"lastName":"Klein","length":224.36526,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Northern Sky","status":200,"ts":1542046781796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Evangelicals","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":28,"lastName":"Klein","length":264.48934,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Skeleton Man","status":200,"ts":1542047005796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Nouvelle Vague","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":29,"lastName":"Klein","length":300.30322,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Say Hello Wave Goodbye","status":200,"ts":1542047269796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Nena Daconte","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":30,"lastName":"Klein","length":140.64281,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"En Que Estrella Estara","status":200,"ts":1542047569796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Airborne Toxic Event","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":31,"lastName":"Klein","length":303.56853,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Sometime Around Midnight","status":200,"ts":1542047709796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":32,"lastName":"Klein","length":191.84281,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Just Friends","status":200,"ts":1542048012796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"La Bouche","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":33,"lastName":"Klein","length":240.79628,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Be My Lover","status":200,"ts":1542048203796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":34,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Settings","registration":1540558108796.0,"sessionId":294,"song":null,"status":200,"ts":1542048218796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Chris Cornell","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":35,"lastName":"Klein","length":240.09098,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"You Know My Name","status":200,"ts":1542048443796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":36,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Home","registration":1540558108796.0,"sessionId":294,"song":null,"status":200,"ts":1542048506796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Wet Wet Wet","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":37,"lastName":"Klein","length":237.71383,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Love Is All Around","status":200,"ts":1542048683796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Postal Service","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":38,"lastName":"Klein","length":226.61179,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Nothing Better (Album)","status":200,"ts":1542048920796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Jedi Mind Tricks","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":39,"lastName":"Klein","length":232.88118,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Suicide","status":200,"ts":1542049146796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"GET","page":"Home","registration":1540006905796.0,"sessionId":501,"song":null,"status":200,"ts":1542049350796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Eve 6","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":1,"lastName":"Arellano","length":249.83465,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":501,"song":"Here's To The Night","status":200,"ts":1542049357796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Polly Paulusma","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":40,"lastName":"Klein","length":222.9024,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Give It Back","status":200,"ts":1542049378796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Touche Amore","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":41,"lastName":"Klein","length":136.95955,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Changing Lanes","status":200,"ts":1542049600796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":2,"lastName":"Arellano","length":236.09424,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":501,"song":"Canada","status":200,"ts":1542049606796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"The Letter Black","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":42,"lastName":"Klein","length":26.93179,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Hanging On By A Thread","status":200,"ts":1542049736796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Dido","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":43,"lastName":"Klein","length":217.83465,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Thank You","status":200,"ts":1542049762796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Evanescence","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":3,"lastName":"Arellano","length":263.78404,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":501,"song":"My Immortal (Album Version)","status":200,"ts":1542049842796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Basshunter Feat. DJ Mental Theo\u0019s Bazzheadz","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":44,"lastName":"Klein","length":152.65914,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Now You're Gone","status":200,"ts":1542049979796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Cut Copy","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":45,"lastName":"Klein","length":71.49669,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Visions","status":200,"ts":1542050131796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Kelly Clarkson","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":46,"lastName":"Klein","length":281.5473,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Already Gone","status":200,"ts":1542050202796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":47,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Settings","registration":1540558108796.0,"sessionId":294,"song":null,"status":200,"ts":1542050253796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Craig's Brother","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":48,"lastName":"Klein","length":175.09832,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Set Free","status":200,"ts":1542050483796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":49,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Settings","registration":1540558108796.0,"sessionId":294,"song":null,"status":200,"ts":1542050497796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Avenged Sevenfold","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":50,"lastName":"Klein","length":333.13914,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Seize The Day (Album Version)","status":200,"ts":1542050658796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Harris","length":null,"level":"free","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1541097374796.0,"sessionId":478,"song":null,"status":200,"ts":1542050920796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"The Chi-Lites","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":51,"lastName":"Klein","length":180.87138,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Oh Girl","status":200,"ts":1542050991796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Stephane Pompougnac","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Harris","length":241.10975,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":478,"song":"Ghosts and Roses","status":200,"ts":1542051108796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Train","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":52,"lastName":"Klein","length":205.45261,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Marry Me","status":200,"ts":1542051171796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":0,"lastName":"Harris","length":null,"level":"free","location":"Eugene, OR","method":"GET","page":"Home","registration":1540906915796.0,"sessionId":513,"song":null,"status":200,"ts":1542051294796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Gojira","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":53,"lastName":"Klein","length":260.20526,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Love","status":200,"ts":1542051376796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Metallica","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":54,"lastName":"Klein","length":267.96363,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Until It Sleeps","status":200,"ts":1542051636796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Gary Wright with Dorian Wright","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":55,"lastName":"Klein","length":237.7922,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Love is Alive (Re-Record)","status":200,"ts":1542051903796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Flipsyde","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":201.87383,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":512,"song":"Get Ready","status":200,"ts":1542051963796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Train","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":56,"lastName":"Klein","length":205.45261,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Marry Me","status":200,"ts":1542052140796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Ray Davies","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":285.3873,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":512,"song":"The Tourist","status":200,"ts":1542052164796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"The Lonely Island","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":57,"lastName":"Klein","length":106.78812,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Like A Boss","status":200,"ts":1542052345796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Starship","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":58,"lastName":"Klein","length":293.35465,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"Sara","status":200,"ts":1542052451796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Los Aut\u00c3\u0083\u00c2\u00a9nticos Decadentes","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":59,"lastName":"Klein","length":218.48771,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":294,"song":"La Guitarra","status":200,"ts":1542052744796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Hot Chip","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":0,"lastName":"Benson","length":283.32363,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"We're Looking For A Lot Of Love","status":200,"ts":1542055373796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Behemoth","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":1,"lastName":"Benson","length":267.31057,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"Ov Fire And The Void","status":200,"ts":1542055656796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":500,"song":null,"status":307,"ts":1542055672796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":500,"song":null,"status":200,"ts":1542055687796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Morningwood","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":176.66567,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":500,"song":"New York Girls","status":200,"ts":1542055715796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":3,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":500,"song":null,"status":200,"ts":1542055814796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":2,"lastName":"Benson","length":268.45995,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"Perhaps Vampires Is A Bit Strong But...","status":200,"ts":1542055923796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Justice","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":3,"lastName":"Benson","length":223.79057,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"One Minute To Midnight","status":200,"ts":1542056191796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":0,"lastName":"Rosales","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1541059521796.0,"sessionId":371,"song":null,"status":200,"ts":1542056391796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"The Audition","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":4,"lastName":"Benson","length":188.08118,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"Lawyers (Album Version)","status":200,"ts":1542056414796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Angus & Julia Stone","auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":1,"lastName":"Rosales","length":236.95628,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541059521796.0,"sessionId":371,"song":"Just A Boy","status":200,"ts":1542056445796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"California Swag District","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":5,"lastName":"Benson","length":239.17669,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"Teach Me How To Dougie","status":200,"ts":1542056602796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":null,"level":"free","location":"Santa Rosa, CA","method":"GET","page":"Home","registration":1540880381796.0,"sessionId":429,"song":null,"status":200,"ts":1542056622796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"Jami Smith","auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":2,"lastName":"Rosales","length":243.80036,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541059521796.0,"sessionId":371,"song":"Home","status":200,"ts":1542056681796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"Stephen Lynch","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":6,"lastName":"Benson","length":52.81914,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"What If That Guy From Smashing Pumpkins Lost His Car Keys?","status":200,"ts":1542056841796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Major Organ And The Adding Machine","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":7,"lastName":"Benson","length":129.77587,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"Water Dripping On Bread Makes Bread Taste Not So Tasty.","status":200,"ts":1542056893796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Alejandro Fernandez","auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":3,"lastName":"Rosales","length":177.21424,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541059521796.0,"sessionId":371,"song":"Matalas","status":200,"ts":1542056924796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"Fania All Stars","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":8,"lastName":"Benson","length":350.09261,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"Ublabadu","status":200,"ts":1542057022796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Livvi Franc","auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":4,"lastName":"Rosales","length":380.99546,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541059521796.0,"sessionId":371,"song":"Automatik","status":200,"ts":1542057101796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"The Lonely Island","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":9,"lastName":"Benson","length":106.78812,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"Like A Boss","status":200,"ts":1542057372796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Pixie Lott","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":10,"lastName":"Benson","length":182.33424,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"Boys And Girls (Album Version)","status":200,"ts":1542057478796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Donna Lewis","auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":5,"lastName":"Rosales","length":240.95302,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541059521796.0,"sessionId":371,"song":"I Love You Always Forever ( LP Version )","status":200,"ts":1542057481796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"Godsmack","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":11,"lastName":"Benson","length":249.96526,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"Saints And Sinners","status":200,"ts":1542057660796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Kid Cudi","auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":6,"lastName":"Rosales","length":227.34322,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541059521796.0,"sessionId":371,"song":"Up Up & Away","status":200,"ts":1542057721796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"Faith Hill","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":12,"lastName":"Benson","length":222.30159,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"There You'll Be (Album Version)","status":200,"ts":1542057909796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Coldplay","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":13,"lastName":"Benson","length":307.51302,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":494,"song":"Clocks","status":200,"ts":1542058131796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Blind Melon","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":221.90975,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"Change","status":200,"ts":1542060004796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":348.57751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"Undo","status":200,"ts":1542060225796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Help","registration":1540794356796.0,"sessionId":481,"song":null,"status":200,"ts":1542060924796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"49ers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":216.68526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"Touch Me","status":200,"ts":1542061342796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":238.99383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"Cold As You","status":200,"ts":1542061558796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Sneaky Sound System","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":243.01669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"UFO","status":200,"ts":1542061796796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":481,"song":null,"status":200,"ts":1542062243796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Copeland","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Rodriguez","length":279.32689,"level":"free","location":"Los Angeles-Long Beach-Anaheim, CA","method":"PUT","page":"NextSong","registration":1540992715796.0,"sessionId":487,"song":"The Day I Lost My Voice (The Suitcase Song)","status":200,"ts":1542062516796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"68"} {"artist":"Foals","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":281.18159,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"Two Steps_ Twice","status":200,"ts":1542062706796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"PJ Harvey","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":245.75955,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"Naked Cousin","status":200,"ts":1542062987796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Goldfrapp","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":251.14077,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"Train","status":200,"ts":1542063232796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Symphony X","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":436.03546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"Absinthe And Rue","status":200,"ts":1542063483796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Fisher","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":133.98159,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"Rianna","status":200,"ts":1542063919796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Pencey Prep","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":160.88771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"PS Don't Write","status":200,"ts":1542064052796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Clear Vu","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":210.57261,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"I Adore","status":200,"ts":1542064212796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Radiohead","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":237.21751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"15 Step","status":200,"ts":1542064422796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Mamas & The Papas","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":190.58893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"Dream A Little Dream Of Me","status":200,"ts":1542064659796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Deepest Blue","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":210.54649,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":481,"song":"Deepest Blue","status":200,"ts":1542064849796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"Logout","registration":1540794356796.0,"sessionId":481,"song":null,"status":307,"ts":1542064850796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":18,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":481,"song":null,"status":200,"ts":1542064863796,"userAgent":null,"userId":""}
467.802817
579
0.696597
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"GET","page":"Home","registration":1540006905796.0,"sessionId":514,"song":null,"status":200,"ts":1542069417796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Fu","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":1,"lastName":"Arellano","length":280.05832,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":514,"song":"Ja I Ty","status":200,"ts":1542069637796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":null,"auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":0,"lastName":"Burke","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540676534796.0,"sessionId":510,"song":null,"status":200,"ts":1542071524796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"All Time Low","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":1,"lastName":"Burke","length":177.84118,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":510,"song":"A Party Song (The Walk of Shame)","status":200,"ts":1542071549796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"Nik & Jay","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":0,"lastName":"Scott","length":196.51873,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":379,"song":"Pop-Pop!","status":200,"ts":1542079142796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Quad City DJ's","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":451.44771,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":506,"song":"C'mon N' Ride It (The Train) (LP Version)","status":200,"ts":1542081112796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":519,"song":null,"status":200,"ts":1542084574796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Noah","gender":"M","itemInSession":0,"lastName":"Chavez","length":null,"level":"free","location":"Ogden-Clearfield, UT","method":"GET","page":"Home","registration":1540970748796.0,"sessionId":492,"song":null,"status":200,"ts":1542085193796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"94"} {"artist":"Hoobastank","auth":"Logged In","firstName":"Noah","gender":"M","itemInSession":1,"lastName":"Chavez","length":232.17587,"level":"free","location":"Ogden-Clearfield, UT","method":"PUT","page":"NextSong","registration":1540970748796.0,"sessionId":492,"song":"Born To Lead","status":200,"ts":1542085206796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"94"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":0,"lastName":"Larson","length":271.38567,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":413,"song":"The Pretender","status":200,"ts":1542090265796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"The Firesign Theatre","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":1,"lastName":"Larson","length":1087.18975,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":413,"song":"Side .002","status":200,"ts":1542090536796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"Julian Lennon","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":2,"lastName":"Larson","length":210.46812,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":413,"song":"Too Late For Goodbyes","status":200,"ts":1542091623796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Home","registration":1540664184796.0,"sessionId":442,"song":null,"status":200,"ts":1542095466796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Kinky","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Graves","length":198.32118,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Sister Twisted","status":200,"ts":1542095665796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The Early November","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Graves","length":250.04363,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Ever So Sweet","status":200,"ts":1542095863796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Damien Rice","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Graves","length":191.39873,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"9 Crimes (Demo)","status":200,"ts":1542096113796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Jimi Hendrix","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":4,"lastName":"Graves","length":296.88118,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Crying Blue Rain","status":200,"ts":1542096304796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Cartola","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":5,"lastName":"Graves","length":173.06077,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Peito Vazio","status":200,"ts":1542096600796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":6,"lastName":"Graves","length":223.32036,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Lady D'Arbanville","status":200,"ts":1542096773796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":7,"lastName":"Graves","length":239.3073,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"You're The One","status":200,"ts":1542096996796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Les Mis\u00c3\u0083\u00c2\u00a9rables - 10th Anniversary Concert","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":8,"lastName":"Graves","length":109.73995,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Do You Hear The People Sing?","status":200,"ts":1542097235796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"America","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":9,"lastName":"Graves","length":173.19138,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Work To Do","status":200,"ts":1542097344796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Dio","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":10,"lastName":"Graves","length":284.55138,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"When A Woman Cries","status":200,"ts":1542097517796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":11,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Home","registration":1540664184796.0,"sessionId":442,"song":null,"status":200,"ts":1542097559796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Dash Berlin","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":12,"lastName":"Graves","length":470.5171,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Till The Sky Falls Down","status":200,"ts":1542097801796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Brian Hyland","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":13,"lastName":"Graves","length":160.13016,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Sealed With A Kiss","status":200,"ts":1542098271796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":14,"lastName":"Graves","length":162.55955,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Your Touch","status":200,"ts":1542098431796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Queensryche","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":15,"lastName":"Graves","length":199.78404,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Circles (2007 Live At The Moore Theater in Seattle LP Version)","status":200,"ts":1542098593796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":16,"lastName":"Graves","length":191.76444,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Howlin\u0019 For You","status":200,"ts":1542098792796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The Killers","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":17,"lastName":"Graves","length":218.85342,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"This Is Your Life","status":200,"ts":1542098983796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Erasure","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":18,"lastName":"Graves","length":584.25424,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Fingers And Thumbs (Cold Summer's Day) (Sound Factory Remix)","status":200,"ts":1542099201796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":0,"lastName":"Summers","length":null,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"GET","page":"Home","registration":1540344794796.0,"sessionId":463,"song":null,"status":200,"ts":1542099753796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Red Hot Chili Peppers","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":19,"lastName":"Graves","length":334.65424,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Snow [Hey Oh] (Album Version)","status":200,"ts":1542099785796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Balkan Beat Box","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":20,"lastName":"Graves","length":352.60036,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Bulgarian Chicks","status":200,"ts":1542100119796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Fleet Foxes","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":21,"lastName":"Graves","length":208.03873,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Tiger Mountain Peasant Song","status":200,"ts":1542100471796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Damu The Fudgemunk","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":22,"lastName":"Graves","length":76.66893,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Man With Bindle [Pawt 1] (2004)","status":200,"ts":1542100679796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Harmonia","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":0,"lastName":"White","length":655.77751,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":380,"song":"Sehr kosmisch","status":200,"ts":1542100680796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Moloko","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":23,"lastName":"Graves","length":593.3971,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Over And Over","status":200,"ts":1542100755796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Richard Ashcroft","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":1,"lastName":"White","length":236.35546,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":380,"song":"Break The Night With Colour","status":200,"ts":1542101335796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":null,"auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":2,"lastName":"White","length":null,"level":"free","location":"Lubbock, TX","method":"GET","page":"Help","registration":1540708070796.0,"sessionId":380,"song":null,"status":200,"ts":1542101346796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Johnny Gill","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":24,"lastName":"Graves","length":288.70485,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Chemistry","status":200,"ts":1542101348796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Enya","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":25,"lastName":"Graves","length":175.85587,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"The Sun In The Stream","status":200,"ts":1542101636796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Eminem","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":26,"lastName":"Graves","length":250.8273,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":442,"song":"Mockingbird","status":200,"ts":1542101811796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":474,"song":null,"status":200,"ts":1542102482796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Van Halen","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":311.61424,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"Love Walks In (Remastered Album Version)","status":200,"ts":1542102512796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"BarlowGirl","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":274.1024,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"Never Alone (Acoustic Version)","status":200,"ts":1542102823796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Porcupine Tree","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":3,"lastName":"Kirby","length":458.00444,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"Way Out of Here [Album Version]","status":200,"ts":1542103097796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Slash","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":4,"lastName":"Kirby","length":278.49098,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"Beautiful Dangerous (featuring Fergie)","status":200,"ts":1542103555796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Lady GaGa","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":5,"lastName":"Kirby","length":274.18077,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"Alejandro","status":200,"ts":1542103833796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Shout Out Louds","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":231.96689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":508,"song":"Never Ever","status":200,"ts":1542104029796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Nick Jonas & The Administration","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":6,"lastName":"Kirby","length":245.57669,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"Who I Am","status":200,"ts":1542104107796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Cibelle","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":576.91383,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":508,"song":"Pequenos Olhos","status":200,"ts":1542104260796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Joshua Radin","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":7,"lastName":"Kirby","length":182.62159,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"The Fear You Won't Fall","status":200,"ts":1542104352796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":8,"lastName":"Kirby","length":201.79546,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"Revelry","status":200,"ts":1542104534796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Spinal Tap","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":9,"lastName":"Kirby","length":304.71791,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"Rock 'n' Roll Creation","status":200,"ts":1542104735796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Nine Inch Nails","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":324.67546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":508,"song":"Beside You In Time","status":200,"ts":1542104836796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Aiden","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":10,"lastName":"Kirby","length":238.65424,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"Breathless (Album Version)","status":200,"ts":1542105039796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Muse","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":441.10322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":508,"song":"Citizen Erased","status":200,"ts":1542105160796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Wyclef Jean","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":11,"lastName":"Kirby","length":319.97342,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"Something About Mary","status":200,"ts":1542105277796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Matthew Good","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":12,"lastName":"Kirby","length":307.06893,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"She's In It for the Money","status":200,"ts":1542105596796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Luke Bryan","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":238.28853,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":508,"song":"Do I","status":200,"ts":1542105601796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Billy Currington","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":223.7122,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":508,"song":"Walk A Little Straighter","status":200,"ts":1542105839796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Justice","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":13,"lastName":"Kirby","length":236.12036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"DVNO","status":200,"ts":1542105903796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Sam Cooke","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":122.04363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":508,"song":"Ain't Misbehavin","status":200,"ts":1542106062796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":14,"lastName":"Kirby","length":284.05506,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"Don't Cry (Original)","status":200,"ts":1542106139796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"DJ Shadow","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":436.24444,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":453,"song":"Changeling","status":200,"ts":1542106173796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Madonna","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":241.21424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":508,"song":"American Life [Headcleanr Rock Mix]","status":200,"ts":1542106184796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Justin Bieber \/ Usher","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":15,"lastName":"Kirby","length":222.30159,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"First Dance","status":200,"ts":1542106423796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Pat Benatar","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":269.26975,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":508,"song":"Invincible","status":200,"ts":1542106425796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The New Pornographers","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":1,"lastName":"Owens","length":173.94893,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":453,"song":"Falling Through Your Clothes","status":200,"ts":1542106609796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Subhumans","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":16,"lastName":"Kirby","length":209.37098,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":474,"song":"Rain","status":200,"ts":1542106645796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":17,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Downgrade","registration":1541022995796.0,"sessionId":474,"song":null,"status":200,"ts":1542106674796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Van Halen","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":198.37342,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":508,"song":"You're No Good (Album Version)","status":200,"ts":1542106694796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Black Ghosts","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":203.28444,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":508,"song":"Anyway You Choose To Give It (Radio Edit)","status":200,"ts":1542106892796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"About","registration":1540472624796.0,"sessionId":508,"song":null,"status":200,"ts":1542106907796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The New Pornographers","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":166.66077,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":430,"song":"Jackie","status":200,"ts":1542109404796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Slim Dusty","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":198.922,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":430,"song":"Long Black Road","status":200,"ts":1542109570796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Muse","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":2,"lastName":"Robinson","length":346.69669,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":430,"song":"Resistance","status":200,"ts":1542109768796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":0,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":486,"song":null,"status":200,"ts":1542114582796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":265.76934,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":528,"song":"Creil City","status":200,"ts":1542114619796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Mossie","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":1,"lastName":"Lynch","length":147.19955,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Interlude #1 (Mama)","status":200,"ts":1542114694796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Anastacia","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":2,"lastName":"Lynch","length":208.45669,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"One Day In Your Life","status":200,"ts":1542114841796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":471,"song":null,"status":200,"ts":1542114870796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Europe","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":346.69669,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":471,"song":"The Final Countdown","status":200,"ts":1542114874796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Renee Olstead","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":251.74159,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":528,"song":"Summertime (Album Version)","status":200,"ts":1542114884796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"John Mayer","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":3,"lastName":"Lynch","length":258.92526,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Good Love Is On The Way","status":200,"ts":1542115049796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Lone Justice","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":273.57995,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":528,"song":"Shelter","status":200,"ts":1542115135796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Beirut","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":0,"lastName":"Santana","length":230.19057,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":475,"song":"Nantes","status":200,"ts":1542115234796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"In Flames","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":4,"lastName":"Lynch","length":278.69995,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"My sweet shadow","status":200,"ts":1542115307796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"New Funky Generation","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":294.03383,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":528,"song":"Lubumba '98","status":200,"ts":1542115408796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Coldplay","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":1,"lastName":"Santana","length":268.38159,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":475,"song":"Yellow","status":200,"ts":1542115464796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Celtic Woman","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":5,"lastName":"Lynch","length":196.96281,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Siulil A Run","status":200,"ts":1542115585796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Delerium feat. Sarah McLachlan","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":494.81098,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":528,"song":"Silence","status":200,"ts":1542115702796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jeff Beck & The Big Town Playboys","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":2,"lastName":"Santana","length":142.44526,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":475,"song":"Blues Stay Away From Me","status":200,"ts":1542115732796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":null,"auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":3,"lastName":"Santana","length":null,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"Logout","registration":1540856629796.0,"sessionId":475,"song":null,"status":307,"ts":1542115733796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":475,"song":null,"status":200,"ts":1542115768796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":5,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":475,"song":null,"status":200,"ts":1542115770796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":6,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":475,"song":null,"status":307,"ts":1542115771796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":7,"lastName":"Santana","length":null,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"GET","page":"Home","registration":1540856629796.0,"sessionId":475,"song":null,"status":200,"ts":1542115772796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"matchbox twenty","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":6,"lastName":"Lynch","length":229.14567,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Unwell (Album Version)","status":200,"ts":1542115781796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"J. Karjalainen & Mustat Lasit","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":8,"lastName":"Santana","length":336.74404,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":475,"song":"Sinisten t\u00c3\u0083\u00c2\u00a4htien alla","status":200,"ts":1542115874796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"GET","page":"Home","registration":1540006905796.0,"sessionId":525,"song":null,"status":200,"ts":1542115949796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Eric B. & Rakim","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":1,"lastName":"Arellano","length":263.91465,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":525,"song":"Move The Crowd","status":200,"ts":1542115979796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Justin Bieber \/ Jessica Jarrell","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":7,"lastName":"Lynch","length":251.16689,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Overboard","status":200,"ts":1542116010796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Harris","length":null,"level":"free","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1541097374796.0,"sessionId":515,"song":null,"status":200,"ts":1542116093796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Mario Rosenstock","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":183.14404,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":528,"song":"FAI Piss-Up 1","status":200,"ts":1542116196796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jermaine Dupri featuring Jay-Z","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Harris","length":254.30159,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":515,"song":"Money Ain't A Thang","status":200,"ts":1542116204796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Terror Squad \/ Big Pun \/ Big L \/ Fat Joe","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":8,"lastName":"Lynch","length":266.70975,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Bring 'Em Back","status":200,"ts":1542116261796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"George Baker Selection","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":200.4371,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":528,"song":"Morning Sky","status":200,"ts":1542116379796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Okkervil River","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":2,"lastName":"Harris","length":223.13751,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":515,"song":"Plus Ones","status":200,"ts":1542116458796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":9,"lastName":"Lynch","length":334.75873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Cold Desert","status":200,"ts":1542116527796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Arcade Fire","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":10,"lastName":"Lynch","length":288.33914,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Neighborhood #1 (Tunnels)","status":200,"ts":1542116861796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Men Without Hats","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":164.49261,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":520,"song":"Safety Dance","status":200,"ts":1542116910796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":524,"song":null,"status":200,"ts":1542117059796,"userAgent":null,"userId":""} {"artist":"Immortal Technique","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":1,"lastName":"Johnson","length":171.12771,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":520,"song":"Bin Laden Feat. MosDef (Inst)","status":200,"ts":1542117074796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"About","registration":null,"sessionId":524,"song":null,"status":200,"ts":1542117103796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":524,"song":null,"status":200,"ts":1542117146796,"userAgent":null,"userId":""} {"artist":"Divinyls","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":11,"lastName":"Lynch","length":232.04526,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Pleasure And Pain","status":200,"ts":1542117149796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":524,"song":null,"status":200,"ts":1542117202796,"userAgent":null,"userId":""} {"artist":"Danny Elfman","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":12,"lastName":"Lynch","length":176.84853,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Prologue","status":200,"ts":1542117381796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Plain White T's","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":13,"lastName":"Lynch","length":232.202,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Hey There Delilah","status":200,"ts":1542117557796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Breaking Benjamin","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":14,"lastName":"Lynch","length":205.322,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Blow Me Away","status":200,"ts":1542117789796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Penguin Caf\u00c3\u0083\u00c2\u00a9 Orchestra","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":15,"lastName":"Lynch","length":269.84444,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Perpetuum Mobile","status":200,"ts":1542117994796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":16,"lastName":"Lynch","length":201.79546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Revelry","status":200,"ts":1542118263796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Banco Del Mutuo Soccorso","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":17,"lastName":"Lynch","length":354.76853,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Di Terra (2006 Digital Remaster)","status":200,"ts":1542118464796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Tanlines","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":18,"lastName":"Lynch","length":279.77098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Real Life","status":200,"ts":1542118818796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Rammstein","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":19,"lastName":"Lynch","length":264.22812,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Engel","status":200,"ts":1542119097796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Sangre Azul","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":20,"lastName":"Lynch","length":274.80771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Noche De Acci\u00c3\u0083\u00c2\u00b3n","status":200,"ts":1542119361796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Zumpano","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":21,"lastName":"Lynch","length":208.06485,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Jeez Louise (Album)","status":200,"ts":1542119635796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":517,"song":null,"status":200,"ts":1542119716796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Kanye West","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":238.52363,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":517,"song":"Flashing Lights","status":200,"ts":1542119731796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":22,"lastName":"Lynch","length":231.81016,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Use Somebody","status":200,"ts":1542119843796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":null,"level":"free","location":"Salinas, CA","method":"GET","page":"Home","registration":1540008898796.0,"sessionId":499,"song":null,"status":200,"ts":1542119948796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Mike And The Mechanics And Paul Carrack","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":1,"lastName":"Hicks","length":308.63628,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":499,"song":"Underscore","status":200,"ts":1542120001796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":23,"lastName":"Lynch","length":227.18649,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Be Somebody","status":200,"ts":1542120074796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Cornelis Vreeswijk","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":24,"lastName":"Lynch","length":140.66893,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"En resa","status":200,"ts":1542120301796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Bon Iver","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":2,"lastName":"Hicks","length":238.49751,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":499,"song":"Skinny Love","status":200,"ts":1542120309796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":25,"lastName":"Lynch","length":290.76853,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Television Rules The Nation \/ Crescendolls","status":200,"ts":1542120441796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Asher Roth \/ Cee-Lo","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":3,"lastName":"Hicks","length":262.66077,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":499,"song":"Be By Myself","status":200,"ts":1542120547796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Suicidal Tendencies","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":26,"lastName":"Lynch","length":172.01587,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Freedumb","status":200,"ts":1542120731796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Be Good Tanyas","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":4,"lastName":"Hicks","length":225.04444,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":499,"song":"A Thousand Tiny Pieces","status":200,"ts":1542120809796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"John Mayer","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":27,"lastName":"Lynch","length":250.38322,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Half Of My Heart","status":200,"ts":1542120903796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Flyleaf","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":28,"lastName":"Lynch","length":174.39302,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Missing","status":200,"ts":1542121153796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":29,"lastName":"Lynch","length":201.79546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Revelry","status":200,"ts":1542121327796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Damian Marley \/ Stephen Marley \/ Rovleta Fraser","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":30,"lastName":"Lynch","length":255.55546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Hey Girl","status":200,"ts":1542121528796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":31,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":486,"song":null,"status":200,"ts":1542121737796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"O Rappa","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":32,"lastName":"Lynch","length":195.83955,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"\u00c3\u0083\u00c2\u0081 Noite","status":200,"ts":1542121783796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Whitest Boy Alive","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":33,"lastName":"Lynch","length":261.85098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Courage","status":200,"ts":1542121978796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Angels Of Light & Akron\/Family","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":34,"lastName":"Lynch","length":150.33424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Awake","status":200,"ts":1542122239796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Belanova","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":35,"lastName":"Lynch","length":187.53261,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Me Pregunto","status":200,"ts":1542122389796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":545,"song":null,"status":200,"ts":1542122560796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":545,"song":null,"status":307,"ts":1542122561796,"userAgent":null,"userId":""} {"artist":"Thee Headcoats","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":36,"lastName":"Lynch","length":160.26077,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Monkey's Paw","status":200,"ts":1542122576796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"matchbox twenty","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":37,"lastName":"Lynch","length":218.72281,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Disease (Album Version)","status":200,"ts":1542122736796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":545,"song":null,"status":200,"ts":1542122748796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Primal Scream","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":38,"lastName":"Lynch","length":226.2722,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Movin' On Up","status":200,"ts":1542122954796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"DJ Krush & Toshinori Kondo","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":39,"lastName":"Lynch","length":279.90159,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Shoh-ka","status":200,"ts":1542123180796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Mindless Faith","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":40,"lastName":"Lynch","length":312.47628,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Independence Day (version)","status":200,"ts":1542123459796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Ella Baila Sola","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":259.00363,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":545,"song":"Y Quisiera","status":200,"ts":1542123589796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":41,"lastName":"Lynch","length":277.15873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1542123771796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Black Moth Super Rainbow","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":221.28281,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":545,"song":"Early 70's Gymnastics","status":200,"ts":1542123848796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Old 97's","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":42,"lastName":"Lynch","length":231.28771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Victoria (LP Version)","status":200,"ts":1542124048796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Dangerous Summer","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":43,"lastName":"Lynch","length":218.33098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Wake Up","status":200,"ts":1542124279796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":44,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":486,"song":null,"status":200,"ts":1542124298796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Randy Travis","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":45,"lastName":"Lynch","length":237.03465,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Hard Rock Bottom Of Your Heart (Single Remix Remastered Version)","status":200,"ts":1542124497796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"M.I.A.","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":46,"lastName":"Lynch","length":206.13179,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Paper Planes","status":200,"ts":1542124734796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Strokes","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":47,"lastName":"Lynch","length":197.53751,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Last Nite","status":200,"ts":1542124940796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Justice","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":48,"lastName":"Lynch","length":295.94077,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Let There Be Light (album version)","status":200,"ts":1542125137796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":49,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":486,"song":null,"status":200,"ts":1542125170796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":null,"level":"free","location":"Salinas, CA","method":"GET","page":"Home","registration":1540008898796.0,"sessionId":547,"song":null,"status":200,"ts":1542125320796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"The Killers","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":1,"lastName":"Hicks","length":220.89098,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":547,"song":"When You Were Young","status":200,"ts":1542125350796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Method Man \/ Busta Rhymes","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":232.22812,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":541,"song":"What's Happenin'","status":200,"ts":1542125425796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":50,"lastName":"Lynch","length":455.52281,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Sympathy For The Devil","status":200,"ts":1542125432796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":2,"lastName":"Hicks","length":194.76853,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":547,"song":"Smile","status":200,"ts":1542125570796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"MGMT","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":1,"lastName":"Arellano","length":264.17587,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":541,"song":"Time To Pretend","status":200,"ts":1542125657796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"The Unicorns","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":3,"lastName":"Hicks","length":222.74567,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":547,"song":"Sea Ghost","status":200,"ts":1542125764796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Widespread Panic","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":51,"lastName":"Lynch","length":400.79628,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Papa's Home","status":200,"ts":1542125887796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Testament","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":52,"lastName":"Lynch","length":253.64853,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Afterlife","status":200,"ts":1542126287796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Gogol Bordello","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":53,"lastName":"Lynch","length":375.45751,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Dub The Frequencies Of Love","status":200,"ts":1542126540796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":537,"song":null,"status":200,"ts":1542126586796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"BT Express","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":352.88771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Do It ('Til You're Satisfied)","status":200,"ts":1542126647796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Tal Bachman","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":54,"lastName":"Lynch","length":224.70485,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"She's So High","status":200,"ts":1542126915796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Jacky Terrasson","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":342.7522,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Le Jardin d'Hiver","status":200,"ts":1542126999796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":55,"lastName":"Lynch","length":199.05261,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Fire Coming Out Of The Monkey's Head","status":200,"ts":1542127139796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":0,"lastName":"Scott","length":null,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"GET","page":"Home","registration":1540872073796.0,"sessionId":527,"song":null,"status":200,"ts":1542127143796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Paul Oakenfold","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":1,"lastName":"Scott","length":254.14485,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":527,"song":"Ready_ Steady_ Go (Album Version)","status":200,"ts":1542127180796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"New Found Glory","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":56,"lastName":"Lynch","length":169.87383,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Better Off Dead","status":200,"ts":1542127338796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Ordinary Boys","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":162.87302,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Boys Will Be Boys","status":200,"ts":1542127341796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Train","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":2,"lastName":"Scott","length":216.76363,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":527,"song":"Hey_ Soul Sister","status":200,"ts":1542127434796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"The Undertones","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":156.36853,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"My Perfect Cousin","status":200,"ts":1542127503796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Queens Of The Stone Age","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":57,"lastName":"Lynch","length":364.90404,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"God Is On The Radio","status":200,"ts":1542127507796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Elliott Smith","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":141.42649,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":550,"song":"Between The Bars","status":200,"ts":1542127529796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"The White Stripes","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":232.61995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Seven Nation Army","status":200,"ts":1542127659796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":537,"song":null,"status":200,"ts":1542127671796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Thursday","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":58,"lastName":"Lynch","length":250.17424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Signals Over The Air","status":200,"ts":1542127871796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Weezer","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":167.3922,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Susanne","status":200,"ts":1542127891796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Baby Bash \/ Russell Lee","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":269.00853,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Sexy Eyes","status":200,"ts":1542128058796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":59,"lastName":"Lynch","length":239.3073,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"You're The One","status":200,"ts":1542128121796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Lara","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":205.58322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"La Otra Princesa","status":200,"ts":1542128327796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":60,"lastName":"Lynch","length":189.1522,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"McFearless","status":200,"ts":1542128360796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Man\u00c3\u0083\u00c2\u00a1","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":252.86485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Rayando el sol","status":200,"ts":1542128532796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Markus Kruneg\u00c3\u0083\u00c2\u00a5rd","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":61,"lastName":"Lynch","length":185.5473,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Genom tunna tyger","status":200,"ts":1542128549796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Local Natives","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":62,"lastName":"Lynch","length":240.8224,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Cards & Quarters","status":200,"ts":1542128734796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"La Roux","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":205.60934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Bulletproof","status":200,"ts":1542128784796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Philipp Poisel","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":63,"lastName":"Lynch","length":258.66404,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Seerosenteich","status":200,"ts":1542128974796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Jedi Mind Tricks","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":12,"lastName":"Harrell","length":244.32281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Ripped To Shreds (feat. Vinnie Paz_ Celph Titled & Demoz)","status":200,"ts":1542128989796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Nightcrawlers","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":64,"lastName":"Lynch","length":264.14975,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Push The Feeling On","status":200,"ts":1542129232796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Tapes \u0018n Tapes","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":13,"lastName":"Harrell","length":191.63383,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Say Back Something","status":200,"ts":1542129233796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Paramore","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":14,"lastName":"Harrell","length":230.45179,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Careful (Album Version)","status":200,"ts":1542129424796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Eric Church","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":65,"lastName":"Lynch","length":190.64118,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Guys Like Me","status":200,"ts":1542129496796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Josh Groban","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":15,"lastName":"Harrell","length":244.45342,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Petit Papa Noel (Album Version)","status":200,"ts":1542129654796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Billy Currington","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":16,"lastName":"Harrell","length":215.82322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Good Directions","status":200,"ts":1542129898796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Mayer Hawthorne","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":17,"lastName":"Harrell","length":179.25179,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Shiny & New","status":200,"ts":1542130113796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Scandinavian Music Group","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":544.88771,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":542,"song":"Kun Puut Tekee Seitti\u00c3\u0083\u00c2\u00a4","status":200,"ts":1542130165796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Macaco","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":284.52526,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":546,"song":"Mama Tierra","status":200,"ts":1542130195796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":546,"song":null,"status":200,"ts":1542130218796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":18,"lastName":"Harrell","length":230.68689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"M1 A1","status":200,"ts":1542130292796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Binary Star","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":19,"lastName":"Harrell","length":157.72689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Slang Blade","status":200,"ts":1542130522796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Mars Volta","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":20,"lastName":"Harrell","length":344.92036,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Aberinkula","status":200,"ts":1542130679796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":66,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Help","registration":1540223723796.0,"sessionId":486,"song":null,"status":200,"ts":1542130747796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"MGMT","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":67,"lastName":"Lynch","length":264.17587,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Time To Pretend","status":200,"ts":1542130757796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":0,"lastName":"Garrison","length":null,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"GET","page":"Home","registration":1540832693796.0,"sessionId":39,"song":null,"status":200,"ts":1542130782796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":"Children Of Bodom","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":68,"lastName":"Lynch","length":204.69506,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Don't Stop At The Top","status":200,"ts":1542131021796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"K's Choice","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":21,"lastName":"Harrell","length":288.57424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Not An Addict","status":200,"ts":1542131023796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Human League","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":69,"lastName":"Lynch","length":265.35138,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Human","status":200,"ts":1542131225796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Elvis Presley","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":22,"lastName":"Harrell","length":273.76281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Suspicious Minds","status":200,"ts":1542131311796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Sleater-kinney","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":70,"lastName":"Lynch","length":190.45832,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"Good Things","status":200,"ts":1542131490796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Bat For Lashes","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":23,"lastName":"Harrell","length":187.71546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Moon And Moon","status":200,"ts":1542131584796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Adam Lambert","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":71,"lastName":"Lynch","length":228.23138,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"If I Had You","status":200,"ts":1542131680796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Base Ball Bear","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":24,"lastName":"Harrell","length":255.60771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Sayonara-Nostalgia","status":200,"ts":1542131771796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Yeah Yeah Yeahs","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":72,"lastName":"Lynch","length":314.46159,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"No No No","status":200,"ts":1542131908796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Nevermore","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":25,"lastName":"Harrell","length":326.53016,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Passenger","status":200,"ts":1542132026796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Jake Hess","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":73,"lastName":"Lynch","length":199.26159,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":486,"song":"You And Me Jesus","status":200,"ts":1542132222796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Stacie Orrico","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":26,"lastName":"Harrell","length":238.78485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"So Pray (Genuine Album Version)","status":200,"ts":1542132352796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":74,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"About","registration":1540223723796.0,"sessionId":486,"song":null,"status":200,"ts":1542132522796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Devo","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":27,"lastName":"Harrell","length":173.81832,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Girl U Want (Live)","status":200,"ts":1542132590796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Chet Baker","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":28,"lastName":"Harrell","length":378.74893,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Blame It on My Youth (From \"Let's Get Lost\")","status":200,"ts":1542132763796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":29,"lastName":"Harrell","length":459.20608,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Sympathy For The Devil","status":200,"ts":1542133141796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":30,"lastName":"Harrell","length":239.3073,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"You're The One","status":200,"ts":1542133600796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Spinners","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":31,"lastName":"Harrell","length":444.13342,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Rubberband Man","status":200,"ts":1542133839796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":32,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":537,"song":null,"status":200,"ts":1542133896796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Diam's","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":33,"lastName":"Harrell","length":284.9171,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Suzy 2003 (Live)","status":200,"ts":1542134283796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Prohom","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Koch","length":246.38649,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":417,"song":"Mise En Bouche","status":200,"ts":1542134377796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Nicholas Hooper","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":34,"lastName":"Harrell","length":104.98567,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Ron's Victory (\"Harry Potter & The Half-Blood Prince\")","status":200,"ts":1542134567796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Drake \/ Lil Wayne \/ Young Jeezy","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Koch","length":225.2273,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":417,"song":"I'm Goin In","status":200,"ts":1542134623796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Traffic","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":35,"lastName":"Harrell","length":195.39546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Something New","status":200,"ts":1542134671796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Straight No Chaser","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":36,"lastName":"Harrell","length":214.88281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"I'm Yours \/ Somewhere Over The Rainbow (EP Version)","status":200,"ts":1542134866796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Leonard Cohen","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":37,"lastName":"Harrell","length":340.53179,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"So Long_ Marianne","status":200,"ts":1542135080796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Strokes","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":38,"lastName":"Harrell","length":208.06485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"The Modern Age","status":200,"ts":1542135420796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Brad Mehldau","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":39,"lastName":"Harrell","length":651.78077,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Moon River (Live) (Album Version)","status":200,"ts":1542135628796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Selena","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":40,"lastName":"Harrell","length":329.58649,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Como La Flor (2005 Re-mastering) (Live)","status":200,"ts":1542136279796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Nirvana","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":41,"lastName":"Harrell","length":219.08853,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Come As You Are","status":200,"ts":1542136608796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Her Bright Skies","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":42,"lastName":"Harrell","length":203.54567,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Heartbreaker","status":200,"ts":1542136827796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":0,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":556,"song":null,"status":200,"ts":1542136956796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Aerosmith","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":43,"lastName":"Harrell","length":235.36281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Pink","status":200,"ts":1542137030796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Stephen Marley","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":44,"lastName":"Harrell","length":255.05914,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Chase Dem","status":200,"ts":1542137265796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Eric Church","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":1,"lastName":"Lynch","length":171.72853,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"My Heart's Got A Memory","status":200,"ts":1542137420796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"David Morales W\/ Tamra Keenan","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":45,"lastName":"Harrell","length":347.27138,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Here I Am (Album Version)","status":200,"ts":1542137520796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Shaggy","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":2,"lastName":"Lynch","length":246.88281,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Boombastic","status":200,"ts":1542137591796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Jacky Terrasson","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":3,"lastName":"Lynch","length":342.7522,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Le Jardin d'Hiver","status":200,"ts":1542137837796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Raymond Van Het Groenewoud","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":46,"lastName":"Harrell","length":163.65669,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Het Nummer Van God","status":200,"ts":1542137867796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Rammstein","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":47,"lastName":"Harrell","length":235.59791,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"TE QUIERO PUTA!","status":200,"ts":1542138030796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Wykked Wytch","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":4,"lastName":"Lynch","length":224.31302,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Ripping Flesh","status":200,"ts":1542138179796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Cartola","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":48,"lastName":"Harrell","length":127.242,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Tive Sim","status":200,"ts":1542138265796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":49,"lastName":"Harrell","length":228.8322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Fortunate Fool","status":200,"ts":1542138392796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Tom Waits","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":5,"lastName":"Lynch","length":197.85098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Whistlin' Past The Graveyard","status":200,"ts":1542138403796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Colbie Caillat","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":6,"lastName":"Lynch","length":196.17914,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Bubbly","status":200,"ts":1542138600796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":50,"lastName":"Harrell","length":268.38159,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Yellow","status":200,"ts":1542138620796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":0,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Home","registration":1540809153796.0,"sessionId":411,"song":null,"status":200,"ts":1542138759796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Does It Offend You_ Yeah?","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":7,"lastName":"Lynch","length":220.57751,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Doomed Now","status":200,"ts":1542138796796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":1,"lastName":"Johnson","length":224.67873,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Secrets","status":200,"ts":1542138839796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Crests","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":51,"lastName":"Harrell","length":182.88281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"16 Candles","status":200,"ts":1542138888796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Mutemath","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":8,"lastName":"Lynch","length":200.51546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Spotlight","status":200,"ts":1542139016796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Muse","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":2,"lastName":"Johnson","length":304.84853,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Uprising","status":200,"ts":1542139063796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Owl City","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":52,"lastName":"Harrell","length":231.67955,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Vanilla Twilight","status":200,"ts":1542139070796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Parachute","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":9,"lastName":"Lynch","length":253.49179,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"The New Year","status":200,"ts":1542139216796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Billy Bob Thornton and The Peasall Sisters","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":53,"lastName":"Harrell","length":164.80608,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Road to Kaintuck","status":200,"ts":1542139301796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Newton Faulkner","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":3,"lastName":"Johnson","length":236.66893,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Dream Catch Me","status":200,"ts":1542139367796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Funkadelic","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":54,"lastName":"Harrell","length":626.07628,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Uncle Jam","status":200,"ts":1542139465796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Scorpions","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":10,"lastName":"Lynch","length":157.04771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"When The Smoke Is Going Down","status":200,"ts":1542139469796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":4,"lastName":"Johnson","length":224.67873,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Secrets","status":200,"ts":1542139603796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Krisiun","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":11,"lastName":"Lynch","length":167.91465,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"In League With Satan","status":200,"ts":1542139626796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Edward Sharpe & The Magnetic Zeros","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":12,"lastName":"Lynch","length":306.31138,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Home","status":200,"ts":1542139793796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Tiger Lou","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":5,"lastName":"Johnson","length":208.45669,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Sam_ As In Samantha","status":200,"ts":1542139827796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Aerosmith","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":6,"lastName":"Johnson","length":319.73832,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Crazy","status":200,"ts":1542140035796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Zac Brown Band","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":55,"lastName":"Harrell","length":197.53751,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Different Kind Of Fine (Album)","status":200,"ts":1542140091796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Slightly Stoopid","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":13,"lastName":"Lynch","length":204.59057,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Bandelero","status":200,"ts":1542140099796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":56,"lastName":"Harrell","length":173.42649,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"Wrong Turn","status":200,"ts":1542140288796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":14,"lastName":"Lynch","length":141.60934,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Bad Moon Rising","status":200,"ts":1542140303796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Erin Bode","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":7,"lastName":"Johnson","length":252.05506,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Here_ There And Everywhere","status":200,"ts":1542140354796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Limi-T 21","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":15,"lastName":"Lynch","length":210.70322,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Estoy Enamorado De Ella (Salsa)","status":200,"ts":1542140444796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Static-X","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":57,"lastName":"Harrell","length":266.47465,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":537,"song":"The Trance Is The Motion [Live]","status":200,"ts":1542140461796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Cage The Elephant","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":8,"lastName":"Johnson","length":175.12444,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Ain't No Rest For The Wicked (Original Version)","status":200,"ts":1542140606796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Kollaa Kest\u00c3\u0083\u00c2\u00a4\u00c3\u0083\u00c2\u00a4","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":16,"lastName":"Lynch","length":101.19791,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Musti Sotakoira (2007 Digital Remaster)","status":200,"ts":1542140654796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Jacky Terrasson","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":17,"lastName":"Lynch","length":342.7522,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Le Jardin d'Hiver","status":200,"ts":1542140755796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Arthur Conley","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":9,"lastName":"Johnson","length":140.69506,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Sweet Soul Music (Single\/LP Version)","status":200,"ts":1542140781796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Five Finger Death Punch","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":10,"lastName":"Johnson","length":200.17587,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Stranger than Fiction","status":200,"ts":1542140921796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Yann Tiersen","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":18,"lastName":"Lynch","length":267.78077,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Le Moulin","status":200,"ts":1542141097796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Vampire Weekend","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":11,"lastName":"Johnson","length":159.81669,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"I Stand Corrected (Album)","status":200,"ts":1542141121796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":12,"lastName":"Johnson","length":348.57751,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Undo","status":200,"ts":1542141280796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Bananarama","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":19,"lastName":"Lynch","length":219.0624,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Venus","status":200,"ts":1542141364796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Red Hot Chili Peppers","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":20,"lastName":"Lynch","length":334.65424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Snow [Hey Oh] (Album Version)","status":200,"ts":1542141583796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":21,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Settings","registration":1540223723796.0,"sessionId":556,"song":null,"status":200,"ts":1542141597796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Adverts","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":13,"lastName":"Johnson","length":122.09587,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"We Who Wait (Single)","status":200,"ts":1542141628796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"She & Him","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":14,"lastName":"Johnson","length":162.66404,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Sweet Darlin'","status":200,"ts":1542141750796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":15,"lastName":"Johnson","length":219.66322,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1542141912796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Police","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":22,"lastName":"Lynch","length":265.79546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"The Bed's Too Big Without You","status":200,"ts":1542141917796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Cinematic Orchestra feat. Lou Rhodes","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":16,"lastName":"Johnson","length":522.68363,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Time and Space","status":200,"ts":1542142131796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Spacehog","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":23,"lastName":"Lynch","length":299.49342,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"In The Meantime (LP Version)","status":200,"ts":1542142182796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Owl City","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":24,"lastName":"Lynch","length":231.67955,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Vanilla Twilight","status":200,"ts":1542142481796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Dead Kennedys","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":17,"lastName":"Johnson","length":160.78322,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Too Drunk to Fuck","status":200,"ts":1542142653796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Game","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":25,"lastName":"Lynch","length":157.88363,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"No More Fun And Games","status":200,"ts":1542142712796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kid Cudi","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":18,"lastName":"Johnson","length":259.00363,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Cudi Zone","status":200,"ts":1542142813796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"M. Pokora","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":26,"lastName":"Lynch","length":198.29506,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Danse Pour Moi","status":200,"ts":1542142869796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kanye West","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":27,"lastName":"Lynch","length":237.47873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Flashing Lights","status":200,"ts":1542143067796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":19,"lastName":"Johnson","length":236.09424,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Canada","status":200,"ts":1542143072796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Pearl Jam","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":28,"lastName":"Lynch","length":67.44771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Encore Break","status":200,"ts":1542143304796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":29,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":556,"song":null,"status":200,"ts":1542143304796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Les Mis\u00c3\u0083\u00c2\u00a9rables - 10th Anniversary Concert","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":20,"lastName":"Johnson","length":128.05179,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Lovely Ladies","status":200,"ts":1542143308796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":21,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Home","registration":1540809153796.0,"sessionId":411,"song":null,"status":200,"ts":1542143350796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Wayne Newton","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":30,"lastName":"Lynch","length":154.74893,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Danke Schoen","status":200,"ts":1542143371796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Rage Against The Machine","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":22,"lastName":"Johnson","length":319.50322,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Bulls On Parade","status":200,"ts":1542143436796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Yeasayer","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":31,"lastName":"Lynch","length":299.38893,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Love Me Girl","status":200,"ts":1542143525796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Alceu Valen\u00c3\u0083\u00c2\u00a7a","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":23,"lastName":"Johnson","length":162.58567,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Recado Falado (Metr\u00c3\u0083\u00c2\u00b4 Da Saudade)","status":200,"ts":1542143755796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Plain White T's","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":32,"lastName":"Lynch","length":232.202,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Hey There Delilah","status":200,"ts":1542143824796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Maxwell","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":24,"lastName":"Johnson","length":255.242,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Pretty Wings","status":200,"ts":1542143917796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Death Cab for Cutie","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":33,"lastName":"Lynch","length":136.12363,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"The Sound of Settling (Album Version)","status":200,"ts":1542144056796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Smile Empty Soul","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":25,"lastName":"Johnson","length":218.61832,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Bottom of a Bottle (Explicit Album Version)","status":200,"ts":1542144172796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Usher","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":34,"lastName":"Lynch","length":252.96934,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"You'll Be In My Heart","status":200,"ts":1542144192796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Corona","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":26,"lastName":"Johnson","length":264.202,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"The Rhythm Of The Night","status":200,"ts":1542144390796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Daisuke Miyatani","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":35,"lastName":"Lynch","length":231.23546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Summer Child","status":200,"ts":1542144444796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Eddie Vedder","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":27,"lastName":"Johnson","length":199.23546,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"End Of The Road","status":200,"ts":1542144654796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"FM Static","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":36,"lastName":"Lynch","length":182.41261,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":556,"song":"Boy Meets Girl (And Vice Versa)","status":200,"ts":1542144675796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Young Money featuring Lloyd","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":0,"lastName":"Cook","length":196.33587,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":364,"song":"BedRock (Radio Edit) (feat.Lloyd)","status":200,"ts":1542144812796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Jukebox The Ghost","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":28,"lastName":"Johnson","length":254.30159,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Good Day","status":200,"ts":1542144853796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Johnny Bristol","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":1,"lastName":"Cook","length":198.1122,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":364,"song":"Hang On In There Baby","status":200,"ts":1542145008796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Tegan And Sara","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":29,"lastName":"Johnson","length":141.50485,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Call It Off (Album Version)","status":200,"ts":1542145107796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Dead Poetic","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":30,"lastName":"Johnson","length":246.38649,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Dimmer Light","status":200,"ts":1542145248796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Howard Jones","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":31,"lastName":"Johnson","length":274.31138,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Dig This Well Deep","status":200,"ts":1542145494796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Mohsen Namjoo","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":32,"lastName":"Johnson","length":395.15383,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Toranj","status":200,"ts":1542145768796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"the bird and the bee","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":33,"lastName":"Johnson","length":246.59546,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Love Letter To Japan","status":200,"ts":1542146163796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Esa Pakarinen","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":34,"lastName":"Johnson","length":141.66159,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Hullu mies hullu","status":200,"ts":1542146409796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":35,"lastName":"Johnson","length":268.61669,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"New Divide (Album Version)","status":200,"ts":1542146550796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":0,"lastName":"Duffy","length":null,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"GET","page":"Home","registration":1540146037796.0,"sessionId":509,"song":null,"status":200,"ts":1542146620796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Lil Wayne \/ Bobby Valentino \/ Kidd Kidd","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":1,"lastName":"Duffy","length":286.95465,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":509,"song":"Mrs. Officer","status":200,"ts":1542146632796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"The Buggles","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":36,"lastName":"Johnson","length":198.08608,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Video Killed The Radio Star","status":200,"ts":1542146818796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Roberto Torres","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":2,"lastName":"Duffy","length":237.84444,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":509,"song":"La Muy_ Muy","status":200,"ts":1542146918796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Frumpies","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":37,"lastName":"Johnson","length":134.47791,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Fuck Kitty","status":200,"ts":1542147016796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":38,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Home","registration":1540809153796.0,"sessionId":411,"song":null,"status":200,"ts":1542147077796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Francisca Valenzuela","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":39,"lastName":"Johnson","length":212.84526,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Afortunada","status":200,"ts":1542147150796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Killers","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":3,"lastName":"Duffy","length":218.85342,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":509,"song":"This Is Your Life","status":200,"ts":1542147155796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Lil Wayne \/ Eminem","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":40,"lastName":"Johnson","length":229.58975,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Drop The World","status":200,"ts":1542147362796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":4,"lastName":"Duffy","length":238.86322,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":509,"song":"Move Along","status":200,"ts":1542147373796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":5,"lastName":"Duffy","length":null,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"GET","page":"Home","registration":1540146037796.0,"sessionId":509,"song":null,"status":200,"ts":1542147438796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"City And Colour","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":41,"lastName":"Johnson","length":228.54485,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Confessions","status":200,"ts":1542147591796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Of Montreal","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":0,"lastName":"Johnson","length":271.38567,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":415,"song":"Faberge Falls For Shuggie","status":200,"ts":1542147804796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"Ilan Eshkeri \/ London Metropolitan Orchestra \/ Andy Brown","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":42,"lastName":"Johnson","length":201.61261,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"The Star Shines","status":200,"ts":1542147819796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Sniff 'n' The Tears","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":43,"lastName":"Johnson","length":220.89098,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Driver's Seat","status":200,"ts":1542148020796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":1,"lastName":"Johnson","length":230.63465,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":415,"song":"Say (All I Need)","status":200,"ts":1542148075796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":44,"lastName":"Johnson","length":212.68853,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Breakdown","status":200,"ts":1542148240796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Collie Buddz","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":2,"lastName":"Johnson","length":224.91383,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":415,"song":"..Come Around","status":200,"ts":1542148305796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":45,"lastName":"Johnson","length":194.55955,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Dirty Little Secret","status":200,"ts":1542148452796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Salvador","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":3,"lastName":"Johnson","length":250.67057,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":415,"song":"Find The Reason (Album Version)","status":200,"ts":1542148529796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":null,"auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":4,"lastName":"Johnson","length":null,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"GET","page":"Help","registration":1541081807796.0,"sessionId":415,"song":null,"status":200,"ts":1542148549796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"The Dresden Dolls","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":46,"lastName":"Johnson","length":286.40608,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Coin-Operated Boy","status":200,"ts":1542148646796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Verve","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":5,"lastName":"Johnson","length":360.25424,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":415,"song":"Bitter Sweet Symphony","status":200,"ts":1542148779796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":null,"auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":6,"lastName":"Johnson","length":null,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"Logout","registration":1541081807796.0,"sessionId":415,"song":null,"status":307,"ts":1542148780796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":7,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":415,"song":null,"status":200,"ts":1542148786796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":8,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":415,"song":null,"status":200,"ts":1542148804796,"userAgent":null,"userId":""} {"artist":"The fFormula","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":47,"lastName":"Johnson","length":239.96036,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Cold Blooded (Acid Cleanse)","status":200,"ts":1542148932796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Brad Paisley","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":48,"lastName":"Johnson","length":256.10404,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Then","status":200,"ts":1542149171796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Sick Of It All","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":49,"lastName":"Johnson","length":52.32281,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Clobberin' Time","status":200,"ts":1542149427796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Killers","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":50,"lastName":"Johnson","length":206.10567,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Why Don't You Find Out For Yourself","status":200,"ts":1542149479796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":51,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Home","registration":1540809153796.0,"sessionId":411,"song":null,"status":200,"ts":1542149480796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Edward Sharpe & The Magnetic Zeros","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":52,"lastName":"Johnson","length":306.31138,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Home","status":200,"ts":1542149685796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Leona Lewis","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":53,"lastName":"Johnson","length":203.88526,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Forgive Me","status":200,"ts":1542149991796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":54,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Home","registration":1540809153796.0,"sessionId":411,"song":null,"status":200,"ts":1542150110796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Cream","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":55,"lastName":"Johnson","length":166.71302,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Tales Of Brave Ulysses","status":200,"ts":1542150194796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":56,"lastName":"Johnson","length":261.74649,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Halo","status":200,"ts":1542150360796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Matthew Jay","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":57,"lastName":"Johnson","length":220.62975,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Become Yourself","status":200,"ts":1542150621796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Reel Big Fish","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":58,"lastName":"Johnson","length":64.67873,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Another F.U. Song (Album)","status":200,"ts":1542150841796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Talib Kweli","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":59,"lastName":"Johnson","length":187.74159,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Eat To Live (Amended Version)","status":200,"ts":1542150905796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"PJ Harvey","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":60,"lastName":"Johnson","length":64.88771,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"No Child Of Mine","status":200,"ts":1542151092796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Wet Wet Wet","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":61,"lastName":"Johnson","length":219.81995,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Goodnight Girl","status":200,"ts":1542151156796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Lifehouse","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":62,"lastName":"Johnson","length":236.25098,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"All In","status":200,"ts":1542151375796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Bram Vermeulen","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":63,"lastName":"Johnson","length":251.42812,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Mamma","status":200,"ts":1542151611796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":64,"lastName":"Johnson","length":348.57751,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Undo","status":200,"ts":1542151862796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":65,"lastName":"Johnson","length":231.60118,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Where Do The Children Play?","status":200,"ts":1542152210796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"El Coyote Y Su Banda Tierra Santa","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":66,"lastName":"Johnson","length":190.51057,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Me Voy A Ir","status":200,"ts":1542152441796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"22-20s","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":67,"lastName":"Johnson","length":237.16526,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Such A Fool","status":200,"ts":1542152631796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Telepopmusik","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":68,"lastName":"Johnson","length":332.95628,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Love Can Damage Your Health","status":200,"ts":1542152868796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Arthur & Yu","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":69,"lastName":"Johnson","length":162.61179,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"The Ghost Of Old Bull Lee","status":200,"ts":1542153200796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":70,"lastName":"Johnson","length":236.09424,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Canada","status":200,"ts":1542153362796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Notorious B.I.G.","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":71,"lastName":"Johnson","length":204.66893,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Ten Commandments (Amended Version)","status":200,"ts":1542153598796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"}
473.180203
604
0.696953
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"The Grass Roots","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":72,"lastName":"Johnson","length":166.71302,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Let's Live For Today","status":200,"ts":1542153802796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Stars","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":73,"lastName":"Johnson","length":298.94485,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Time Can Never Kill The True Heart","status":200,"ts":1542153968796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Eddie Palmieri","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":74,"lastName":"Johnson","length":391.83628,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Nada De Ti","status":200,"ts":1542154266796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Bravery","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":75,"lastName":"Johnson","length":168.14975,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Give In","status":200,"ts":1542154657796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"K.U.K.L","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":76,"lastName":"Johnson","length":181.28934,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Anna","status":200,"ts":1542154825796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Fray","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":77,"lastName":"Johnson","length":209.97179,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Syndicate","status":200,"ts":1542155006796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Chuck Berry","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":78,"lastName":"Johnson","length":147.06893,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Roll Over Beethoven","status":200,"ts":1542155215796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Dimmu Borgir","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":79,"lastName":"Johnson","length":468.47955,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Kings Of The Carnival Creation","status":200,"ts":1542155362796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Jimmy Nail","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":80,"lastName":"Johnson","length":245.65506,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Ain't No Doubt","status":200,"ts":1542155830796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Weezer","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":81,"lastName":"Johnson","length":189.43955,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Pork And Beans","status":200,"ts":1542156075796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":0,"lastName":"Scott","length":null,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"GET","page":"Home","registration":1540872073796.0,"sessionId":551,"song":null,"status":200,"ts":1542156103796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Madcon","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":1,"lastName":"Scott","length":215.92771,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":551,"song":"Beggin'","status":200,"ts":1542156133796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Joe Williams \/ Count Basie","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":82,"lastName":"Johnson","length":184.94649,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Teach Me Tonight","status":200,"ts":1542156264796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Emil Gilels\/Orchestre de la Soci\u00c3\u0083\u00c2\u00a9t\u00c3\u0083\u00c2\u00a9 des Concerts du Conservatoire\/Andr\u00c3\u0083\u00c2\u00a9 Cluytens","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":83,"lastName":"Johnson","length":375.19628,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Piano Concerto No. 2 in G minor Op. 22 (2006 Digital Remaster): III. Presto","status":200,"ts":1542156448796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Modwheelmood","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":84,"lastName":"Johnson","length":209.71057,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":411,"song":"Sunday Morning","status":200,"ts":1542156823796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":85,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Home","registration":1540809153796.0,"sessionId":411,"song":null,"status":200,"ts":1542156862796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":86,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"About","registration":1540809153796.0,"sessionId":411,"song":null,"status":200,"ts":1542157048796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":87,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Home","registration":1540809153796.0,"sessionId":411,"song":null,"status":200,"ts":1542157182796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":539,"song":null,"status":200,"ts":1542162914796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"John Mayer","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":201.16853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Waiting On The World To Change","status":200,"ts":1542164265796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Ten Years After","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":122.3571,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Two Time Mama (2004 Digital Remaster)","status":200,"ts":1542164466796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mudcrutch","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":208.03873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Six Days On The Road (Album Version)","status":200,"ts":1542164588796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Alaska Y Dinarama","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":180.37506,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Ni T\u00c3\u0083\u00c2\u00ba Ni Nadie (Versi\u00c3\u0083\u00c2\u00b3n Demo)","status":200,"ts":1542164796796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kicking K8","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":176.48281,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Liar","status":200,"ts":1542164976796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Badly Drawn Boy","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":318.51057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"The Shining","status":200,"ts":1542165152796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":548,"song":null,"status":200,"ts":1542165199796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Disturbed","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":247.09179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Pain Redefined (Album Version)","status":200,"ts":1542165470796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Phoenix","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":278.80444,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Armistice","status":200,"ts":1542165717796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Margaret Becker","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":251.84608,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"The Hunger Stays","status":200,"ts":1542165995796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Lady GaGa","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":220.65587,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Teeth","status":200,"ts":1542166246796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Corinne Bailey Rae","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":206.18404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Trouble Sleeping","status":200,"ts":1542166466796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Royksopp","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":303.62077,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Miss It So Much","status":200,"ts":1542166672796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Apocalyptica","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":221.07383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Enter Sandman","status":200,"ts":1542166975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Usher featuring will.i.am","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":395.72853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"OMG","status":200,"ts":1542167196796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Alivia","gender":"F","itemInSession":0,"lastName":"Terrell","length":null,"level":"free","location":"Parkersburg-Vienna, WV","method":"GET","page":"Home","registration":1540505391796.0,"sessionId":3,"song":null,"status":200,"ts":1542167277796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"4"} {"artist":"The Killers","auth":"Logged In","firstName":"Alivia","gender":"F","itemInSession":1,"lastName":"Terrell","length":246.80444,"level":"free","location":"Parkersburg-Vienna, WV","method":"PUT","page":"NextSong","registration":1540505391796.0,"sessionId":3,"song":"Read My Mind","status":200,"ts":1542167283796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"4"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":277.15873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1542167591796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Interpol","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":487.67955,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Public Pervert","status":200,"ts":1542167868796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Clay Walker","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":167.99302,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"What's It To You (Album Version)","status":200,"ts":1542168355796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"DMX","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":18,"lastName":"Levine","length":259.65669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"One More Road To Cross","status":200,"ts":1542168522796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Dakota Oak","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":19,"lastName":"Levine","length":45.63546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Baker's Blue Jay Yarn","status":200,"ts":1542168781796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Coldplay","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":20,"lastName":"Levine","length":268.30322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Yellow","status":200,"ts":1542168826796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Deadmau5","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":21,"lastName":"Levine","length":521.19465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Faxing Berlin","status":200,"ts":1542169094796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Shaggy \/ Ricardo Ducent","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":22,"lastName":"Levine","length":226.76853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"It Wasn't Me","status":200,"ts":1542169615796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"R.E.M.","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":23,"lastName":"Levine","length":202.4224,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Talk About The Passion","status":200,"ts":1542169841796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Michelle Shocked","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":24,"lastName":"Levine","length":217.83465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Quality Of Mercy","status":200,"ts":1542170043796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Cradle Of Filth","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":25,"lastName":"Levine","length":371.66975,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Better To Reign In Hell","status":200,"ts":1542170260796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bond","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":26,"lastName":"Levine","length":210.9122,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Scorchio","status":200,"ts":1542170631796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Home","registration":1540266185796.0,"sessionId":484,"song":null,"status":200,"ts":1542170773796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Vieja Trova Santiaguera","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":27,"lastName":"Levine","length":222.58893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Cuida Eso","status":200,"ts":1542170841796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jonas Brothers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":28,"lastName":"Levine","length":153.46893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"S.O.S.","status":200,"ts":1542171063796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"KC And The Sunshine Band","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":1,"lastName":"Cruz","length":301.03465,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":484,"song":"Get Down Tonight (Miami Mix)","status":200,"ts":1542171216796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Alejandro Sanz","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":29,"lastName":"Levine","length":277.44608,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Te lo agradezco_ pero no","status":200,"ts":1542171216796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bleeding Through","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":30,"lastName":"Levine","length":171.67628,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"The Truth (Sick Of It All Cover Version)","status":200,"ts":1542171493796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Eminem","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":2,"lastName":"Cruz","length":323.49995,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":484,"song":"Criminal","status":200,"ts":1542171517796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"MoZella","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":31,"lastName":"Levine","length":203.41506,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"You Wanted It (Album Version)","status":200,"ts":1542171664796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":32,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Downgrade","registration":1540794356796.0,"sessionId":548,"song":null,"status":200,"ts":1542171833796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Laurel & Hardy","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":3,"lastName":"Cruz","length":123.71546,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":484,"song":"At the Ball_ That's All","status":200,"ts":1542171840796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Jack's Mannequin","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":33,"lastName":"Levine","length":194.89914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"The Mixed Tape (Album Version)","status":200,"ts":1542171867796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Percubaba","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":4,"lastName":"Cruz","length":124.78649,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":484,"song":"Intro","status":200,"ts":1542171963796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Eagles","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":34,"lastName":"Levine","length":241.78893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Take The Devil (LP Version)","status":200,"ts":1542172061796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Rilo Kiley","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":5,"lastName":"Cruz","length":322.42893,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":484,"song":"A Man\/Me\/Then Jim (Album Version)","status":200,"ts":1542172087796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Rise Against","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":35,"lastName":"Levine","length":245.96853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Audience Of One","status":200,"ts":1542172302796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Watain","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":6,"lastName":"Cruz","length":303.25506,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":484,"song":"Sworn To The Dark","status":200,"ts":1542172409796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Nickel Creek","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":36,"lastName":"Levine","length":187.55873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Scotch & Chocolate","status":200,"ts":1542172547796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Ricardo Arjona","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":7,"lastName":"Cruz","length":210.25914,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":484,"song":"Como Duele (Album)","status":200,"ts":1542172712796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Sherwood","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":37,"lastName":"Levine","length":122.77506,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"The last to know","status":200,"ts":1542172734796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":38,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Help","registration":1540794356796.0,"sessionId":548,"song":null,"status":200,"ts":1542173227796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":39,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Help","registration":1540794356796.0,"sessionId":548,"song":null,"status":200,"ts":1542173329796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Gordon Lightfoot","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":40,"lastName":"Levine","length":172.61669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Steel Rail Blues","status":200,"ts":1542173527796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Temper Trap","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":41,"lastName":"Levine","length":192.67873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Fader","status":200,"ts":1542173699796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Moby","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":42,"lastName":"Levine","length":228.25751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"South Side","status":200,"ts":1542173891796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Toby Keith","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":43,"lastName":"Levine","length":207.46404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"How Do You Like Me Now?!","status":200,"ts":1542174119796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Joe Vasconcellos","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":44,"lastName":"Levine","length":255.92118,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Me Demoro (vivo)","status":200,"ts":1542174326796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mike Jones","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":45,"lastName":"Levine","length":222.58893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Next To You (Explicit Album Version)","status":200,"ts":1542174581796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"MercyME","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":46,"lastName":"Levine","length":257.51465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"In You","status":200,"ts":1542174803796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Cooper","length":null,"level":"free","location":"Columbia, SC","method":"GET","page":"Home","registration":1541058203796.0,"sessionId":58,"song":null,"status":200,"ts":1542174899796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.2; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"59"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Cooper","length":null,"level":"free","location":"Columbia, SC","method":"PUT","page":"Logout","registration":1541058203796.0,"sessionId":58,"song":null,"status":307,"ts":1542174900796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.2; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"59"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":58,"song":null,"status":200,"ts":1542174903796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":58,"song":null,"status":200,"ts":1542174941796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":58,"song":null,"status":307,"ts":1542174942796,"userAgent":null,"userId":""} {"artist":"Disturbed","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":223.45098,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":553,"song":"Just Stop (Album Version)","status":200,"ts":1542174986796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":5,"lastName":"Cooper","length":null,"level":"free","location":"Columbia, SC","method":"GET","page":"Home","registration":1541058203796.0,"sessionId":58,"song":null,"status":200,"ts":1542175029796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.2; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"59"} {"artist":"Armand Van Helden & A-TRAK Present Duck Sauce","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":47,"lastName":"Levine","length":325.0673,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"aNYway","status":200,"ts":1542175060796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":6,"lastName":"Cooper","length":185.99138,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1541058203796.0,"sessionId":58,"song":"Crying Shame","status":200,"ts":1542175073796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.2; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"59"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":265.76934,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":553,"song":"Creil City","status":200,"ts":1542175209796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"blessthefall","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":7,"lastName":"Cooper","length":166.45179,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1541058203796.0,"sessionId":58,"song":"Higinia (Album Version)","status":200,"ts":1542175258796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.2; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"59"} {"artist":"The Spades","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":48,"lastName":"Levine","length":84.84526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Gotta Get Some","status":200,"ts":1542175385796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Subhumans","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":49,"lastName":"Levine","length":209.37098,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Rain","status":200,"ts":1542175469796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Killswitch Engage","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":50,"lastName":"Levine","length":257.20118,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"This Is Goodbye (Album Version)","status":200,"ts":1542175678796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Wishbone Ash","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":51,"lastName":"Levine","length":221.54404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Persephone","status":200,"ts":1542175935796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Cartola","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":52,"lastName":"Levine","length":127.242,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Tive Sim","status":200,"ts":1542176156796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Joa~o Gilberto","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":53,"lastName":"Levine","length":98.14159,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Samba De Una Nota So\u00c3\u0082\u00c2\u00b4","status":200,"ts":1542176283796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Blufeld","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":54,"lastName":"Levine","length":396.93016,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"On A Deeper Level","status":200,"ts":1542176381796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Braden","gender":"M","itemInSession":0,"lastName":"Parker","length":null,"level":"free","location":"Youngstown-Warren-Boardman, OH-PA","method":"GET","page":"Home","registration":1540999292796.0,"sessionId":457,"song":null,"status":200,"ts":1542176662796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"74"} {"artist":"Carpenters","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":55,"lastName":"Levine","length":276.06159,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"(They Long To Be) Close To You","status":200,"ts":1542176777796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Komeda","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":56,"lastName":"Levine","length":261.72036,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Brother","status":200,"ts":1542177053796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bond","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":0,"lastName":"George","length":181.68118,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Fuego","status":200,"ts":1542177299796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":1,"lastName":"George","length":null,"level":"free","location":"Birmingham-Hoover, AL","method":"GET","page":"Upgrade","registration":1541020249796.0,"sessionId":479,"song":null,"status":200,"ts":1542177313796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Hooters","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":57,"lastName":"Levine","length":240.43057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Johnny B.","status":200,"ts":1542177314796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":2,"lastName":"George","length":null,"level":"free","location":"Birmingham-Hoover, AL","method":"PUT","page":"Submit Upgrade","registration":1541020249796.0,"sessionId":479,"song":null,"status":307,"ts":1542177314796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":261.74649,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":529,"song":"Halo","status":200,"ts":1542177340796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":3,"lastName":"George","length":null,"level":"paid","location":"Birmingham-Hoover, AL","method":"GET","page":"Home","registration":1541020249796.0,"sessionId":479,"song":null,"status":200,"ts":1542177373796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Dido","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":4,"lastName":"George","length":217.83465,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Thank You","status":200,"ts":1542177480796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"John Michael Montgomery","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":5,"lastName":"George","length":217.0771,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Beer And Bones","status":200,"ts":1542177697796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Sarah Connor \/ Naturally 7","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":6,"lastName":"George","length":277.10649,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Music Is The Key","status":200,"ts":1542177914796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":58,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Downgrade","registration":1540794356796.0,"sessionId":548,"song":null,"status":200,"ts":1542178148796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Macaco","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":7,"lastName":"George","length":202.4224,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Con La Mano Levant\u00c3\u0083\u00c2\u00a1","status":200,"ts":1542178191796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Franz Ferdinand","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":8,"lastName":"George","length":254.69342,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"This Fire","status":200,"ts":1542178393796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Green Day","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":59,"lastName":"Levine","length":185.12934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"American Idiot [feat. Green Day & The Cast Of American Idiot] (Album Version)","status":200,"ts":1542178630796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":9,"lastName":"George","length":218.95791,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Everybody Loves Me","status":200,"ts":1542178647796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Aqua","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":60,"lastName":"Levine","length":201.92608,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Doctor Jones","status":200,"ts":1542178815796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Craig Chaquico","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":10,"lastName":"George","length":279.64036,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Kyle's World","status":200,"ts":1542178865796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Joshua Radin","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":61,"lastName":"Levine","length":169.32526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"I'd Rather Be With You","status":200,"ts":1542179016796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Memphis Jug Band","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":11,"lastName":"George","length":150.80444,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"K.C. Moan","status":200,"ts":1542179144796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Underoath","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":62,"lastName":"Levine","length":268.042,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"A Boy Brushed Red Living In Black And White","status":200,"ts":1542179185796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Roses Are Red","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":12,"lastName":"George","length":258.82077,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Time Signals Progress","status":200,"ts":1542179294796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Jay-Z","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":63,"lastName":"Levine","length":212.27057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"D'Evils","status":200,"ts":1542179453796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Marilyn Manson","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":13,"lastName":"George","length":218.8273,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"The Beautiful People","status":200,"ts":1542179552796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":64,"lastName":"Levine","length":232.09751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Tim McGraw","status":200,"ts":1542179665796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Erasure","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":14,"lastName":"George","length":584.25424,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Fingers And Thumbs (Cold Summer's Day) (Sound Factory Remix)","status":200,"ts":1542179770796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Casiotone For The Painfully Alone","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":65,"lastName":"Levine","length":210.12853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Hot Boyz (w\/ Dear Nora)","status":200,"ts":1542179897796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Corrs","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":66,"lastName":"Levine","length":205.94893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Breathless","status":200,"ts":1542180107796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Black Stone Cherry","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":67,"lastName":"Levine","length":261.79873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Big City Lights (Album Version)","status":200,"ts":1542180312796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Kooks","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":15,"lastName":"George","length":203.96363,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Naive","status":200,"ts":1542180354796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Band Of Horses","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":16,"lastName":"George","length":203.25832,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Marry Song (Album)","status":200,"ts":1542180557796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":68,"lastName":"Levine","length":163.70893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Gift From Virgo","status":200,"ts":1542180573796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Metric","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":69,"lastName":"Levine","length":245.52444,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Gold Guns Girls","status":200,"ts":1542180736796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Miley Cyrus","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":17,"lastName":"George","length":180.84526,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Hoedown Throwdown","status":200,"ts":1542180760796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":18,"lastName":"George","length":null,"level":"paid","location":"Birmingham-Hoover, AL","method":"GET","page":"Home","registration":1541020249796.0,"sessionId":479,"song":null,"status":200,"ts":1542180760796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Stars","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":19,"lastName":"George","length":225.82812,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Violent","status":200,"ts":1542180940796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"K'Naan","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":70,"lastName":"Levine","length":220.49914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Wavin' Flag","status":200,"ts":1542180981796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Corrs","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":20,"lastName":"George","length":238.44526,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"When The Stars Go Blue (Featuring Bono) (Disclab Remix)","status":200,"ts":1542181165796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Binary Star","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":71,"lastName":"Levine","length":362.84036,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Evolution Of Man","status":200,"ts":1542181201796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":21,"lastName":"George","length":219.66322,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1542181403796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Reverend And The Makers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":72,"lastName":"Levine","length":209.81506,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Heavyweight Champion Of The World","status":200,"ts":1542181563796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Les Humphries Singers","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":22,"lastName":"George","length":222.79791,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Mama Loo","status":200,"ts":1542181622796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"John Waite","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":73,"lastName":"Levine","length":269.76608,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Missing You","status":200,"ts":1542181772796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"CKY","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":23,"lastName":"George","length":240.27383,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Familiar Realm","status":200,"ts":1542181844796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"R.I.O.","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":74,"lastName":"Levine","length":217.12934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"When The Sun Comes Down","status":200,"ts":1542182041796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":24,"lastName":"George","length":261.74649,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Halo","status":200,"ts":1542182084796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Calle 13","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":75,"lastName":"Levine","length":196.98893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Electro Movimiento","status":200,"ts":1542182258796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Chris Bathgate","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":25,"lastName":"George","length":324.98893,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Coda","status":200,"ts":1542182345796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Discovery","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":76,"lastName":"Levine","length":192.522,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"So Insane","status":200,"ts":1542182454796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Alivia","gender":"F","itemInSession":0,"lastName":"Terrell","length":null,"level":"free","location":"Parkersburg-Vienna, WV","method":"GET","page":"Home","registration":1540505391796.0,"sessionId":566,"song":null,"status":200,"ts":1542182631796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"4"} {"artist":"Griffin House","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":77,"lastName":"Levine","length":226.42893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Better Than Love","status":200,"ts":1542182646796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":26,"lastName":"George","length":172.22485,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"The Maestro","status":200,"ts":1542182669796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Ann","gender":"F","itemInSession":0,"lastName":"Banks","length":null,"level":"free","location":"Salt Lake City, UT","method":"GET","page":"Home","registration":1540895683796.0,"sessionId":421,"song":null,"status":200,"ts":1542182794796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"99"} {"artist":"Raphael Saadiq featuring Stevie Wonder and CJ","auth":"Logged In","firstName":"Ann","gender":"F","itemInSession":1,"lastName":"Banks","length":252.94322,"level":"free","location":"Salt Lake City, UT","method":"PUT","page":"NextSong","registration":1540895683796.0,"sessionId":421,"song":"Never Give You Up","status":200,"ts":1542182809796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"99"} {"artist":"Dead Meadow","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":27,"lastName":"George","length":181.41995,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Keep On Walking","status":200,"ts":1542182841796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"59 Times the Pain","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":78,"lastName":"Levine","length":144.95302,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Found Home","status":200,"ts":1542182872796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":0,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"Home","registration":1540907087796.0,"sessionId":522,"song":null,"status":200,"ts":1542183015796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Third World","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":79,"lastName":"Levine","length":268.79955,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"1865 (96\u00c3\u0082\u00c2\u00ba In The Shade)","status":200,"ts":1542183016796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Nine Inch Nails","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":1,"lastName":"Benson","length":293.69424,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Dead Souls (LP Version)","status":200,"ts":1542183020796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Bon Jovi","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":28,"lastName":"George","length":250.69669,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Livin' On A Prayer","status":200,"ts":1542183022796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Kid Cudi \/ MGMT \/ Ratatat","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":29,"lastName":"George","length":295.67955,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Pursuit Of Happiness (nightmare)","status":200,"ts":1542183272796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Maria Beth\u00c3\u0083\u00c2\u00a2nia","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":80,"lastName":"Levine","length":212.34893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"Onde Estara O Meu Amor","status":200,"ts":1542183284796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"David Cook","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":2,"lastName":"Benson","length":248.00608,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Come Back to Me","status":200,"ts":1542183313796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Green Day","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":81,"lastName":"Levine","length":185.12934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":548,"song":"American Idiot [feat. Green Day & The Cast Of American Idiot] (Album Version)","status":200,"ts":1542183496796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Feist","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":3,"lastName":"Benson","length":183.58812,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"1234","status":200,"ts":1542183561796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"The Cat Empire","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":30,"lastName":"George","length":200.35873,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"The Lost Song","status":200,"ts":1542183567796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Angels and Airwaves","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":302.05342,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":568,"song":"The Gift","status":200,"ts":1542183668796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Brisa Roch\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":4,"lastName":"Benson","length":48.19546,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Intermission 1","status":200,"ts":1542183744796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Saving Abel","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":31,"lastName":"George","length":258.42893,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Sailed Away","status":200,"ts":1542183767796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Mystery Jets","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":5,"lastName":"Benson","length":245.02812,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Hand Me Down","status":200,"ts":1542183792796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Upgrade","registration":1540940782796.0,"sessionId":568,"song":null,"status":200,"ts":1542183976796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eminem","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":32,"lastName":"George","length":284.18567,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"The Real Slim Shady","status":200,"ts":1542184025796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Anna Ternheim","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":6,"lastName":"Benson","length":166.86975,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"To Be Gone","status":200,"ts":1542184037796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Color Me Badd","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":7,"lastName":"Benson","length":259.63057,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Close To Heaven (Album Version)","status":200,"ts":1542184203796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Upgrade","registration":1540940782796.0,"sessionId":568,"song":null,"status":200,"ts":1542184235796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":null,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"Submit Upgrade","registration":1540940782796.0,"sessionId":568,"song":null,"status":307,"ts":1542184236796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jimmy Eat World","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":33,"lastName":"George","length":166.00771,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"The Middle","status":200,"ts":1542184309796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":568,"song":null,"status":200,"ts":1542184383796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Reel Big Fish","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":8,"lastName":"Benson","length":289.61914,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"We Care","status":200,"ts":1542184462796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"The Upsetters","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":34,"lastName":"George","length":231.44444,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Dub So","status":200,"ts":1542184475796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Insane Clown Posse","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":35,"lastName":"George","length":262.89587,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Piggy Pie (Old School)","status":200,"ts":1542184706796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Strokes","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":9,"lastName":"Benson","length":218.56608,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Reptilia","status":200,"ts":1542184751796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Yazoo","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":36,"lastName":"George","length":269.16526,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Good Times","status":200,"ts":1542184968796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Thrice","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":10,"lastName":"Benson","length":291.76118,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Of Dust And Nations","status":200,"ts":1542184969796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Jacky Terrasson","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":342.7522,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":568,"song":"Le Jardin d'Hiver","status":200,"ts":1542185228796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Armin van Buuren","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":37,"lastName":"George","length":452.23138,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Never Say Never","status":200,"ts":1542185237796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Relient K","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":11,"lastName":"Benson","length":138.81424,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Silent Night\/Away In A Manger (Album Version)","status":200,"ts":1542185260796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Nick Cave & The Bad Seeds","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":12,"lastName":"Benson","length":265.27302,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Spell","status":200,"ts":1542185398796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Akcent","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":235.44118,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":568,"song":"9 Mai","status":200,"ts":1542185570796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Riverboat Gamblers","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":13,"lastName":"Benson","length":122.04363,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Hey! Hey! Hey!","status":200,"ts":1542185663796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Ikonika","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":38,"lastName":"George","length":157.25669,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Continue?","status":200,"ts":1542185689796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Tallest Man On Earth","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":14,"lastName":"Benson","length":175.43791,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Thousand Ways","status":200,"ts":1542185785796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Drowning Pool","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":201.63873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":568,"song":"Bodies","status":200,"ts":1542185805796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":39,"lastName":"George","length":null,"level":"paid","location":"Birmingham-Hoover, AL","method":"GET","page":"Home","registration":1541020249796.0,"sessionId":479,"song":null,"status":200,"ts":1542185816796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Justin Timberlake","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":40,"lastName":"George","length":313.0771,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"What Goes Around...Comes Around","status":200,"ts":1542185846796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Pussycat Dolls","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":15,"lastName":"Benson","length":221.3873,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Magic","status":200,"ts":1542185960796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"KC And The Sunshine Band","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":262.1122,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":568,"song":"It's The Same Old Song","status":200,"ts":1542186006796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Gary Allan","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":41,"lastName":"George","length":237.53098,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Today","status":200,"ts":1542186159796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Rebelution","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":16,"lastName":"Benson","length":244.55791,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Suffering","status":200,"ts":1542186181796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Jaci Velasquez","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":200.95955,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":568,"song":"Something (Album Version)","status":200,"ts":1542186268796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Nate Dogg feat. Warren G","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":42,"lastName":"George","length":271.59465,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Nobody Does It Better","status":200,"ts":1542186396796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Soulja Boy Tell'em","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":17,"lastName":"Benson","length":224.91383,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Crank That (Soulja Boy)","status":200,"ts":1542186425796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Chuck Berry","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":147.06893,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":568,"song":"Roll Over Beethoven","status":200,"ts":1542186468796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Band Of Horses","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":50.59873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":568,"song":"Lamb on the Lam (In the City) (Album)","status":200,"ts":1542186615796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":18,"lastName":"Benson","length":239.3073,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"You're The One","status":200,"ts":1542186649796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"The Format","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":43,"lastName":"George","length":225.802,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":479,"song":"Inches And Falling (I Love_ Love) (Live)","status":200,"ts":1542186667796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Help","registration":1540940782796.0,"sessionId":568,"song":null,"status":200,"ts":1542186670796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"K-OS","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":189.64853,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":568,"song":"I Wish I Knew Natalie Portman","status":200,"ts":1542186737796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":19,"lastName":"Benson","length":151.562,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Me & Mr Jones","status":200,"ts":1542186888796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Harmonia","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":655.77751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":568,"song":"Sehr kosmisch","status":200,"ts":1542186926796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Steely Dan","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":20,"lastName":"Benson","length":138.84036,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"With A Gun","status":200,"ts":1542187039796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Katrina & The Waves","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":21,"lastName":"Benson","length":199.73179,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"The Game Of Love","status":200,"ts":1542187177796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"The Pussycat Dolls","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":22,"lastName":"Benson","length":200.9073,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Love The Way You Love Me","status":200,"ts":1542187376796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Decyfer Down","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":23,"lastName":"Benson","length":214.17751,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"I'll Breathe For You","status":200,"ts":1542187576796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Bow Wow & Omarion","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":284.83873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":568,"song":"Girlfriend","status":200,"ts":1542187581796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Home","registration":1540266185796.0,"sessionId":567,"song":null,"status":200,"ts":1542187769796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"The Velvet Underground \/ Nico","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":24,"lastName":"Benson","length":360.09751,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"All Tomorrow's Parties","status":200,"ts":1542187790796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":null,"level":"free","location":"New Haven-Milford, CT","method":"GET","page":"Error","registration":1540931983796.0,"sessionId":538,"song":null,"status":404,"ts":1542188076796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"The Killers","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":225.12281,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":538,"song":"A Dustland Fairytale","status":200,"ts":1542188091796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Kassav'","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":25,"lastName":"Benson","length":446.74567,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Medley Jacob","status":200,"ts":1542188150796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":0,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":559,"song":null,"status":200,"ts":1542188427796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Tragically Hip","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":26,"lastName":"Benson","length":226.16771,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Coffee Girl","status":200,"ts":1542188596796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Ryan Adams","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":1,"lastName":"Lynch","length":145.08363,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Everybody Knows","status":200,"ts":1542188705796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"El Cuarteto De Nos","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":27,"lastName":"Benson","length":280.2673,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Hoy Estoy Raro","status":200,"ts":1542188822796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":2,"lastName":"Lynch","length":316.18567,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Over And Out","status":200,"ts":1542188850796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Phil Keaggy","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":28,"lastName":"Benson","length":376.0322,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Paintin' The Town (Album Version)","status":200,"ts":1542189102796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Local H","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":3,"lastName":"Lynch","length":223.00689,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Bound For The Floor","status":200,"ts":1542189166796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"David Benoit","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":4,"lastName":"Lynch","length":288.96608,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Jump Start","status":200,"ts":1542189389796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Gang Of Four","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":29,"lastName":"Benson","length":207.25506,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":522,"song":"Damaged Goods","status":200,"ts":1542189478796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":30,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"About","registration":1540907087796.0,"sessionId":522,"song":null,"status":200,"ts":1542189606796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Darius Rucker","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":5,"lastName":"Lynch","length":230.39955,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Alright","status":200,"ts":1542189677796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Chris Bathgate","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":6,"lastName":"Lynch","length":324.98893,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Coda","status":200,"ts":1542189907796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Offspring","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":7,"lastName":"Lynch","length":163.3171,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"It'll Be a Long Time (Album Version)","status":200,"ts":1542190231796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":8,"lastName":"Lynch","length":189.1522,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"McFearless","status":200,"ts":1542190394796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Caribou","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":9,"lastName":"Lynch","length":282.33098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Kaili","status":200,"ts":1542190583796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Nine Inch Nails","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":10,"lastName":"Lynch","length":373.2371,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Closer","status":200,"ts":1542190865796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"ATB","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":11,"lastName":"Lynch","length":191.7122,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Rising Moon","status":200,"ts":1542191238796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Coldplay","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":12,"lastName":"Lynch","length":268.38159,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Yellow","status":200,"ts":1542191429796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Cage The Elephant","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":13,"lastName":"Lynch","length":175.12444,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Ain't No Rest For The Wicked (Original Version)","status":200,"ts":1542191697796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":14,"lastName":"Lynch","length":236.93016,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Bubble Toes","status":200,"ts":1542191872796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Klaxons","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":15,"lastName":"Lynch","length":166.79138,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Golden Skans","status":200,"ts":1542192108796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Three 6 Mafia vs. Ti\u00c3\u0083\u00c2\u00absto with Sean Kingston and Flo Rida","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":16,"lastName":"Lynch","length":241.05751,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Feel It","status":200,"ts":1542192274796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kid Cudi","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":17,"lastName":"Lynch","length":259.00363,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Cudi Zone","status":200,"ts":1542192515796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Rihanna","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":18,"lastName":"Lynch","length":269.37424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Don't Stop The Music","status":200,"ts":1542192774796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":557,"song":null,"status":200,"ts":1542193004796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Brooks & Dunn","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Koch","length":191.79057,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"He's Got You","status":200,"ts":1542193015796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"ILS","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":19,"lastName":"Lynch","length":350.61506,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"No Soul (High Contrast Remix)","status":200,"ts":1542193043796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Reel Big Fish","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Koch","length":190.69342,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"Ban The Tube Top","status":200,"ts":1542193206796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Pearl Jam","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":20,"lastName":"Lynch","length":161.48853,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Oceans","status":200,"ts":1542193393796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Lucero","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Koch","length":231.94077,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"I'll Just Fall","status":200,"ts":1542193396796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Armin van Buuren","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":21,"lastName":"Lynch","length":452.23138,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Never Say Never","status":200,"ts":1542193554796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Usher Featuring Lil' Jon & Ludacris","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Koch","length":250.38322,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"Yeah!","status":200,"ts":1542193627796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":null,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"GET","page":"Home","registration":1540829025796.0,"sessionId":498,"song":null,"status":200,"ts":1542193747796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Ice Cube","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":252.02893,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":498,"song":"It Was A Good Day","status":200,"ts":1542193779796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"The New Pornographers","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":5,"lastName":"Koch","length":206.81098,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"Use It","status":200,"ts":1542193877796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Righteous Brothers","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":22,"lastName":"Lynch","length":215.90159,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Unchained Melody","status":200,"ts":1542194006796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Toto La Momposina","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":2,"lastName":"Hess","length":299.02322,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":498,"song":"Curura","status":200,"ts":1542194031796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Motion City Soundtrack","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":6,"lastName":"Koch","length":206.34077,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"Everything Is Alright (Album Version)","status":200,"ts":1542194083796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":7,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Help","registration":1541048010796.0,"sessionId":557,"song":null,"status":200,"ts":1542194141796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Misfits","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":23,"lastName":"Lynch","length":45.47873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Kong Unleashed (Album Version)","status":200,"ts":1542194221796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kid Cudi \/ MGMT \/ Ratatat","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":24,"lastName":"Lynch","length":295.67955,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Pursuit Of Happiness (nightmare)","status":200,"ts":1542194266796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Drowning Pool","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":8,"lastName":"Koch","length":201.63873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"Bodies","status":200,"ts":1542194289796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Cocteau Twins","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":9,"lastName":"Koch","length":110.602,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"Strange Fruit","status":200,"ts":1542194490796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Owl City","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":25,"lastName":"Lynch","length":267.65016,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"The Technicolor Phase","status":200,"ts":1542194561796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Billy Currington","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":10,"lastName":"Koch","length":215.82322,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"Good Directions","status":200,"ts":1542194600796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Soul II Soul","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":11,"lastName":"Koch","length":239.67302,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"How Long","status":200,"ts":1542194815796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"David Gray","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":26,"lastName":"Lynch","length":304.77016,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Disappearing World (Album Version)","status":200,"ts":1542194828796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Bill Engvall","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":12,"lastName":"Koch","length":148.84526,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"Here's Your Sign Christmas (Album Version)","status":200,"ts":1542195054796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":27,"lastName":"Lynch","length":233.69098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Invalid","status":200,"ts":1542195132796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Eels","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":13,"lastName":"Koch","length":199.65342,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"Efils' God","status":200,"ts":1542195202796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Frightened Rabbit","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":28,"lastName":"Lynch","length":278.72608,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Yes_ I Would","status":200,"ts":1542195365796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Hit-O-Matic","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":14,"lastName":"Koch","length":229.27628,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"Melody Of Life","status":200,"ts":1542195401796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"zebrahead","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":15,"lastName":"Koch","length":187.34975,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"With Legs Like That","status":200,"ts":1542195630796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":29,"lastName":"Lynch","length":315.42812,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Born On The Bayou","status":200,"ts":1542195643796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":16,"lastName":"Koch","length":250.14812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"Everlong","status":200,"ts":1542195817796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Atheist","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":30,"lastName":"Lynch","length":241.05751,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"On They Slay","status":200,"ts":1542195958796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Killers","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":17,"lastName":"Koch","length":327.91465,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"Romeo And Juliet","status":200,"ts":1542196067796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"T.I.","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":31,"lastName":"Lynch","length":214.77832,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Why You Wanna (Amended Album Version)","status":200,"ts":1542196199796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Tori Amos Featuring Damien Rice","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":18,"lastName":"Koch","length":215.82322,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"The Power of Orange Knickers","status":200,"ts":1542196394796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Peggy Zina","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":32,"lastName":"Lynch","length":287.00689,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Ftes","status":200,"ts":1542196413796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Anna Tatangelo","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":218.93179,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":552,"song":"Il Mio Amico","status":200,"ts":1542196566796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Dave Grusin","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":19,"lastName":"Koch","length":255.50322,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":557,"song":"St. Elsewhere","status":200,"ts":1542196609796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Tim Christensen","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":204.17261,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":558,"song":"Jump The Gun","status":200,"ts":1542196640796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":20,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Downgrade","registration":1541048010796.0,"sessionId":557,"song":null,"status":200,"ts":1542196651796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bon Iver","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":33,"lastName":"Lynch","length":329.24689,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Blindsided","status":200,"ts":1542196700796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Exies","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":217.88689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":558,"song":"Baptize Me","status":200,"ts":1542196844796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Whitest Boy Alive","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":34,"lastName":"Lynch","length":191.29424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Fireworks (bonus track)","status":200,"ts":1542197029796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kanye West","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":238.52363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":558,"song":"Flashing Lights","status":200,"ts":1542197061796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bright Eyes","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":35,"lastName":"Lynch","length":279.87546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Poison Oak (Album Version)","status":200,"ts":1542197220796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Felt","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":171.57179,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":558,"song":"Sunlight Bathed the Golden Glow","status":200,"ts":1542197299796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"Logout","registration":1540472624796.0,"sessionId":558,"song":null,"status":307,"ts":1542197300796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":5,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":558,"song":null,"status":200,"ts":1542197341796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":6,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":558,"song":null,"status":307,"ts":1542197342796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":558,"song":null,"status":200,"ts":1542197358796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Alice Deejay","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":216.5024,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":558,"song":"Better Off Alone","status":200,"ts":1542197470796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Murder By Death","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":36,"lastName":"Lynch","length":182.25587,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Ball & Chain","status":200,"ts":1542197499796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Smash Mouth","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":37,"lastName":"Lynch","length":206.36689,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Walkin' On The Sun","status":200,"ts":1542197681796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Nine Inch Nails","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":229.82485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":558,"song":"Just Like You Imagined","status":200,"ts":1542197686796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Lauryn Hill","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":38,"lastName":"Lynch","length":280.81587,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Tell Him","status":200,"ts":1542197887796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":220.89098,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":558,"song":"Somebody To Love","status":200,"ts":1542197915796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":571,"song":null,"status":200,"ts":1542197954796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Junior Kimbrough And The Soul Blues Boys","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":350.58893,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":571,"song":"All Night Long","status":200,"ts":1542198084796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Holy Fuck","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":428.72118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":558,"song":"Tonebank Computer","status":200,"ts":1542198135796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Jes","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":39,"lastName":"Lynch","length":233.87383,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Closer","status":200,"ts":1542198167796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Killers","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":40,"lastName":"Lynch","length":220.89098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"When You Were Young","status":200,"ts":1542198400796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Anberlin","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":41,"lastName":"Lynch","length":178.23302,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Stationary Stationery","status":200,"ts":1542198620796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Travie McCoy","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":42,"lastName":"Lynch","length":211.12118,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Billionaire [feat. Bruno Mars] (Explicit Album Version)","status":200,"ts":1542198798796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Marc Almond","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":43,"lastName":"Lynch","length":387.65669,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Only The Moment (All The Time In The World Mix)","status":200,"ts":1542199009796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Guildo Horn","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":44,"lastName":"Lynch","length":240.37832,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Aber Dich Gibt's Nur Einmal F\u00c3\u0083\u00c2\u00bcr Mich","status":200,"ts":1542199396796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"DJ Paul","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":45,"lastName":"Lynch","length":208.45669,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"You Scared","status":200,"ts":1542199636796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Elliott Smith","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":46,"lastName":"Lynch","length":141.42649,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Between The Bars","status":200,"ts":1542199844796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Angus & Julia Stone","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":47,"lastName":"Lynch","length":295.81016,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Silver Coin","status":200,"ts":1542199985796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Umberto Tozzi","auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":0,"lastName":"Ayala","length":369.13587,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"PUT","page":"NextSong","registration":1541007976796.0,"sessionId":495,"song":"Gabbie","status":200,"ts":1542200143796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":"Lonnie Gordon","auth":"Logged In","firstName":"Connar","gender":"M","itemInSession":0,"lastName":"Moreno","length":181.21098,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540823606796.0,"sessionId":476,"song":"Catch You Baby (Steve Pitron & Max Sanna Radio Edit)","status":200,"ts":1542200188796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10) AppleWebKit\/538.46 (KHTML, like Gecko) Version\/8.0 Safari\/538.46\"","userId":"62"} {"artist":"50 Cent","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":48,"lastName":"Lynch","length":249.52118,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"P.I.M.P.","status":200,"ts":1542200280796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Olivia Newton-John","auth":"Logged In","firstName":"Connar","gender":"M","itemInSession":1,"lastName":"Moreno","length":132.23138,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540823606796.0,"sessionId":476,"song":"Hochmah (Interlude)","status":200,"ts":1542200369796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10) AppleWebKit\/538.46 (KHTML, like Gecko) Version\/8.0 Safari\/538.46\"","userId":"62"} {"artist":"snoop Dogg Featuring The Dramatics_ Lil' Half Dead","auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":1,"lastName":"Ayala","length":319.99955,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"PUT","page":"NextSong","registration":1541007976796.0,"sessionId":495,"song":"Ballin' (Explicit) (Feat. The Dramatics_ Lil' Half Dead)","status":200,"ts":1542200512796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":49,"lastName":"Lynch","length":396.82567,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Da Funk \/ Dadftendirekt","status":200,"ts":1542200529796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Radiohead","auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":2,"lastName":"Ayala","length":255.42485,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"PUT","page":"NextSong","registration":1541007976796.0,"sessionId":495,"song":"Talk Show Host","status":200,"ts":1542200831796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":"Phil Collins","auth":"Logged In","firstName":"Alivia","gender":"F","itemInSession":0,"lastName":"Terrell","length":291.00363,"level":"free","location":"Parkersburg-Vienna, WV","method":"PUT","page":"NextSong","registration":1540505391796.0,"sessionId":572,"song":"Something Happened On The Way To Heaven","status":200,"ts":1542200857796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"4"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":50,"lastName":"Lynch","length":196.91057,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"All Hands Against His Own","status":200,"ts":1542200925796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Lupe Fiasco","auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":3,"lastName":"Ayala","length":273.94567,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"PUT","page":"NextSong","registration":1541007976796.0,"sessionId":495,"song":"Shining Down [feat. Matthew Santos] (Amended Album Version)","status":200,"ts":1542201086796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":"Franz Ferdinand","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":51,"lastName":"Lynch","length":247.24853,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Take Me Out","status":200,"ts":1542201121796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Spill Canvas","auth":"Logged In","firstName":"Alivia","gender":"F","itemInSession":1,"lastName":"Terrell","length":204.90404,"level":"free","location":"Parkersburg-Vienna, WV","method":"PUT","page":"NextSong","registration":1540505391796.0,"sessionId":572,"song":"Bracelets (LP Version)","status":200,"ts":1542201148796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"4"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":52,"lastName":"Lynch","length":231.81016,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Use Somebody","status":200,"ts":1542201368796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":null,"level":"free","location":"Santa Rosa, CA","method":"GET","page":"Home","registration":1540880381796.0,"sessionId":544,"song":null,"status":200,"ts":1542201587796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"James Blunt","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":1,"lastName":"Johnson","length":257.95873,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":544,"song":"Goodbye My Lover","status":200,"ts":1542201595796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"The Hush Sound","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":53,"lastName":"Lynch","length":196.28363,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"We Intertwined (Album Version)","status":200,"ts":1542201599796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":54,"lastName":"Lynch","length":238.86322,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Move Along","status":200,"ts":1542201795796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Joseph Arthur","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":55,"lastName":"Lynch","length":167.75791,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Enough To Get Away With","status":200,"ts":1542202033796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Nek","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":56,"lastName":"Lynch","length":211.12118,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Parliamo al singolare","status":200,"ts":1542202200796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Joe Satriani","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":57,"lastName":"Lynch","length":201.63873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Always With Me_ Always With You","status":200,"ts":1542202411796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Iron & Wine","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":58,"lastName":"Lynch","length":205.89669,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Each Coming Night","status":200,"ts":1542202612796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Scritti Politti","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":59,"lastName":"Lynch","length":286.9024,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":559,"song":"Wood Beez","status":200,"ts":1542202817796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":60,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"Logout","registration":1540223723796.0,"sessionId":559,"song":null,"status":307,"ts":1542202818796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":61,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":559,"song":null,"status":200,"ts":1542202839796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Connar","gender":"M","itemInSession":0,"lastName":"Moreno","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540823606796.0,"sessionId":585,"song":null,"status":200,"ts":1542208193796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10) AppleWebKit\/538.46 (KHTML, like Gecko) Version\/8.0 Safari\/538.46\"","userId":"62"} {"artist":"The Bats","auth":"Logged In","firstName":"Connar","gender":"M","itemInSession":1,"lastName":"Moreno","length":367.12444,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540823606796.0,"sessionId":585,"song":"Crow Song","status":200,"ts":1542208259796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10) AppleWebKit\/538.46 (KHTML, like Gecko) Version\/8.0 Safari\/538.46\"","userId":"62"} {"artist":"Wolfmother","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":280.86812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Joker And The Thief","status":200,"ts":1542208393796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Starting Rock Feat. Diva Avari","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Graves","length":367.62077,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":534,"song":"Don't Go","status":200,"ts":1542208494796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":565,"song":null,"status":200,"ts":1542208538796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Connar","gender":"M","itemInSession":2,"lastName":"Moreno","length":187.50649,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540823606796.0,"sessionId":585,"song":"Wordplay (Album Version)","status":200,"ts":1542208626796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10) AppleWebKit\/538.46 (KHTML, like Gecko) Version\/8.0 Safari\/538.46\"","userId":"62"} {"artist":"Klaxons","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":161.07057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Totem On The Timeline","status":200,"ts":1542208673796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Caifanes","auth":"Logged In","firstName":"Connar","gender":"M","itemInSession":3,"lastName":"Moreno","length":273.99791,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540823606796.0,"sessionId":585,"song":"Nubes","status":200,"ts":1542208813796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10) AppleWebKit\/538.46 (KHTML, like Gecko) Version\/8.0 Safari\/538.46\"","userId":"62"} {"artist":"Information Society","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":281.80853,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":565,"song":"The Seeds of Pain","status":200,"ts":1542208815796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Nirvana","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":218.06975,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"You Know You're Right","status":200,"ts":1542208834796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Erykah Badu","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Graves","length":336.45669,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":534,"song":"Me","status":200,"ts":1542208861796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Kid Cudi","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":227.34322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Up Up & Away","status":200,"ts":1542209052796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"That Petrol Emotion","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":265.1424,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":565,"song":"Sooner Or Later","status":200,"ts":1542209096796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"K-Ci & JoJo","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Graves","length":331.31057,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":534,"song":"All My Life","status":200,"ts":1542209197796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":216,"song":null,"status":307,"ts":1542209250796,"userAgent":null,"userId":""} {"artist":"Neil Young","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":557.13914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Love And Only Love (1991 Live LP Version)","status":200,"ts":1542209279796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Zachary","gender":"M","itemInSession":1,"lastName":"Thomas","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540644861796.0,"sessionId":216,"song":null,"status":200,"ts":1542209289796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.7; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"19"} {"artist":"The Smiths","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Graves","length":159.08526,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":534,"song":"Cemetery Gates","status":200,"ts":1542209528796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Enrique Iglesias","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":4,"lastName":"Graves","length":217.99138,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":534,"song":"D\u00c3\u0083\u00c2\u00admelo","status":200,"ts":1542209687796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"You Me At Six","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":366.41914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Always Attract","status":200,"ts":1542209836796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kanye West","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":5,"lastName":"Graves","length":242.93832,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":534,"song":"We Don't Care","status":200,"ts":1542209904796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Mariah Carey \/ Twista","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":6,"lastName":"Graves","length":194.7424,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":534,"song":"One And Only","status":200,"ts":1542210146796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Screamin' Jay Hawkins","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":265.50812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Heart Attack and Vine","status":200,"ts":1542210202796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Justin Timberlake","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":7,"lastName":"Graves","length":283.84608,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":534,"song":"Like I Love You","status":200,"ts":1542210340796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":8,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Home","registration":1540664184796.0,"sessionId":534,"song":null,"status":200,"ts":1542210392796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Marc Et Claude","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":220.86485,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":549,"song":"I Need Your Lovin' (Like The Sunshine) (Radio Edit)","status":200,"ts":1542210466796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Sparklehorse","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":220.3424,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Marigold","status":200,"ts":1542210467796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":1,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"Logout","registration":1540006905796.0,"sessionId":549,"song":null,"status":307,"ts":1542210467796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":549,"song":null,"status":200,"ts":1542210487796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"About","registration":null,"sessionId":549,"song":null,"status":200,"ts":1542210499796,"userAgent":null,"userId":""} {"artist":"Hollywood Undead","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":9,"lastName":"Graves","length":185.20771,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":534,"song":"No. 5","status":200,"ts":1542210623796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Violet Indiana","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":226.87302,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Hiding","status":200,"ts":1542210687796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Coldplay","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":0,"lastName":"Barrera","length":318.6673,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":493,"song":"Politik","status":200,"ts":1542210731796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":1,"lastName":"Barrera","length":268.61669,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":493,"song":"New Divide (Album Version)","status":200,"ts":1542211049796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":574,"song":null,"status":200,"ts":1542211604796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Eliza Doolittle","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":200.30649,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Police Car","status":200,"ts":1542211914796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Great Lake Swimmers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":228.54485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Bodies and Minds","status":200,"ts":1542212114796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":null,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"GET","page":"Home","registration":1540829025796.0,"sessionId":580,"song":null,"status":200,"ts":1542212308796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Jackson Conti","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":158.64118,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Tijuca Man","status":200,"ts":1542212342796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Parov Stelar","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":281.5473,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"KissKiss","status":200,"ts":1542212500796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Skalpel","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":163.49995,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":504,"song":"Test Drive","status":200,"ts":1542212704796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Tiga & Zyntherius","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":502.85669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Sunglasses At Night","status":200,"ts":1542212781796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Master P","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":1,"lastName":"Gonzalez","length":205.42649,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":504,"song":"Light It Up (LP Version)","status":200,"ts":1542212867796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Jimmy Eat World","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":2,"lastName":"Gonzalez","length":385.802,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":504,"song":"Drugs Or Me","status":200,"ts":1542213072796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Justin Timberlake","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":277.9424,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"LoveStoned\/I Think She Knows","status":200,"ts":1542213283796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"FM Static","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":170.81424,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Definitely Maybe","status":200,"ts":1542213560796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":null,"level":"free","location":"New Haven-Milford, CT","method":"GET","page":"Home","registration":1540931983796.0,"sessionId":578,"song":null,"status":200,"ts":1542213635796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Bill Conti","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":169.97832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Gonna Fly Now (Theme From \"Rocky\")","status":200,"ts":1542213730796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":224.83546,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":578,"song":"Crying Lightning","status":200,"ts":1542213742796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Eagles","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":18,"lastName":"Levine","length":372.29669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Hotel California","status":200,"ts":1542213899796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Postal Service","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":19,"lastName":"Levine","length":266.47465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Such Great Heights","status":200,"ts":1542214271796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Scott Matthews","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":20,"lastName":"Levine","length":299.72853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"City Headache","status":200,"ts":1542214537796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mazzy Star","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":21,"lastName":"Levine","length":222.1971,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Unreflected","status":200,"ts":1542214836796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Pendulum","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":22,"lastName":"Levine","length":312.97261,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Blood sugar","status":200,"ts":1542215058796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Avril Lavigne","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":23,"lastName":"Levine","length":244.50567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Complicated","status":200,"ts":1542215370796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"El Koala","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":24,"lastName":"Levine","length":213.62893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Lola","status":200,"ts":1542215614796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Musiq","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":25,"lastName":"Levine","length":304.69179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Love","status":200,"ts":1542215827796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Los Pericos","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":26,"lastName":"Levine","length":263.44444,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Nada Que Perder (Live)","status":200,"ts":1542216131796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Holy Fuck","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":0,"lastName":"Santana","length":209.76281,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":540,"song":"Milkshake","status":200,"ts":1542216442796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":27,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":574,"song":null,"status":200,"ts":1542216629796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Cash Cash","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":1,"lastName":"Santana","length":212.16608,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":540,"song":"Electric Hearts","status":200,"ts":1542216651796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"OutKast","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":2,"lastName":"Santana","length":140.17261,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":540,"song":"God","status":200,"ts":1542216863796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Tab Benoit","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":3,"lastName":"Santana","length":221.09995,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":540,"song":"Jambalaya","status":200,"ts":1542217003796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Atomic Kitten","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":28,"lastName":"Levine","length":197.32853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Eternal Flame (Single Version)","status":200,"ts":1542217084796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"August Burns Red","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":4,"lastName":"Santana","length":252.21179,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":540,"song":"Composure","status":200,"ts":1542217224796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Nickelback","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":29,"lastName":"Levine","length":248.05832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"If Today Was Your Last Day (Album Version)","status":200,"ts":1542217281796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Dropkick Murphys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":30,"lastName":"Levine","length":205.66159,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"The Wild Rover (Album Version)","status":200,"ts":1542217529796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Nocturnal Rites","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":31,"lastName":"Levine","length":260.62322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"The Vision","status":200,"ts":1542217734796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Tony Bennett & k.d. lang","auth":"Logged In","firstName":"Kynnedi","gender":"F","itemInSession":0,"lastName":"Sanchez","length":188.26404,"level":"free","location":"Cedar Rapids, IA","method":"PUT","page":"NextSong","registration":1541079034796.0,"sessionId":334,"song":"That's My Home","status":200,"ts":1542217951796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_8_5) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"89"} {"artist":"Wyclef Jean featuring Akon_ Lil Wayne_ and introducing Niia","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":32,"lastName":"Levine","length":239.43791,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Sweetest Girl (Dollar Bill)","status":200,"ts":1542217994796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Z\u00c3\u0083\u00c2\u00a9lia Duncan","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":33,"lastName":"Levine","length":170.78812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Catedral ( Catedral Song)","status":200,"ts":1542218233796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":34,"lastName":"Levine","length":348.57751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Undo","status":200,"ts":1542218403796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Massive Attack","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":35,"lastName":"Levine","length":251.24526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Exchange","status":200,"ts":1542218751796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Miley Cyrus","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":36,"lastName":"Levine","length":182.9873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Someday","status":200,"ts":1542219002796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Aztec Camera","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":37,"lastName":"Levine","length":204.72118,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Walk Out To Winter","status":200,"ts":1542219184796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Spinetta Jade","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":38,"lastName":"Levine","length":270.31465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"El Hombre Dirigente","status":200,"ts":1542219388796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Planet X","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":39,"lastName":"Levine","length":299.38893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Snuff","status":200,"ts":1542219658796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":40,"lastName":"Levine","length":224.67873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Secrets","status":200,"ts":1542219957796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Justin Timberlake","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":41,"lastName":"Levine","length":355.99628,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"LoveStoned\/I Think She Knows","status":200,"ts":1542220181796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Specials","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":42,"lastName":"Levine","length":174.10567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"A Message To You Rudy","status":200,"ts":1542220536796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Pearl Jam","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":43,"lastName":"Levine","length":268.7473,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Better Man","status":200,"ts":1542220710796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Big & Rich","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":44,"lastName":"Levine","length":212.74077,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Lost In This Moment","status":200,"ts":1542220978796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Survivor","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":45,"lastName":"Levine","length":245.36771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Eye Of The Tiger","status":200,"ts":1542221190796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540306145796.0,"sessionId":460,"song":null,"status":200,"ts":1542221303796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Sam Sparro","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":46,"lastName":"Levine","length":247.17016,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Sick","status":200,"ts":1542221435796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Breaking Benjamin","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":47,"lastName":"Levine","length":216.31955,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Forget It","status":200,"ts":1542221682796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Toro Y Moi","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":48,"lastName":"Levine","length":224.33914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Thanks Vision","status":200,"ts":1542221898796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"3OH!3","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":49,"lastName":"Levine","length":196.28363,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"DONTTRUSTME [BENNYBLANCOREMIX] FEATURINGKIDCUDI (Explicit Bonus Version)","status":200,"ts":1542222122796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Polly Paulusma","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":50,"lastName":"Levine","length":222.9024,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Give It Back","status":200,"ts":1542222318796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"China Crisis","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":51,"lastName":"Levine","length":219.32363,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Black Man Ray","status":200,"ts":1542222540796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Me'Shell Ndegeocello","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":52,"lastName":"Levine","length":334.86322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Elliptical","status":200,"ts":1542222759796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Laurent Voulzy","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":53,"lastName":"Levine","length":240.92689,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Belle-Ile-En-Mer","status":200,"ts":1542223093796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jo\u00c3\u0083\u00c2\u00a3o Gilberto","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":54,"lastName":"Levine","length":258.37669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":574,"song":"Ave Maria No Morro","status":200,"ts":1542223333796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":55,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"Logout","registration":1540794356796.0,"sessionId":574,"song":null,"status":307,"ts":1542223334796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":56,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":574,"song":null,"status":200,"ts":1542224289796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":57,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":574,"song":null,"status":200,"ts":1542224314796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":58,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"About","registration":null,"sessionId":574,"song":null,"status":200,"ts":1542224330796,"userAgent":null,"userId":""} {"artist":"Keith Sweat","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":312.99873,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":419,"song":"In Your Eyes (LP Version)","status":200,"ts":1542225833796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Phoenix","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":195.91791,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":603,"song":"Rally","status":200,"ts":1542226073796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"MC 900 Ft. Jesus","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":331.31057,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":603,"song":"The City Sleeps","status":200,"ts":1542226268796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Gwen Stefani","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Fox","length":216.76363,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":603,"song":"Danger Zone","status":200,"ts":1542226599796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"VHS Or Beta","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Fox","length":216.94649,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":603,"song":"You Got Me","status":200,"ts":1542226815796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":4,"lastName":"Fox","length":348.57751,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":603,"song":"Undo","status":200,"ts":1542227031796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":5,"lastName":"Fox","length":194.66404,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":603,"song":"Not Big","status":200,"ts":1542227379796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Radiohead","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":6,"lastName":"Fox","length":231.91465,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":603,"song":"(Nice Dream)","status":200,"ts":1542227573796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":7,"lastName":"Fox","length":239.3073,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":603,"song":"You're The One","status":200,"ts":1542227804796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":584,"song":null,"status":200,"ts":1542232303796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Downgrade","registration":1540472624796.0,"sessionId":584,"song":null,"status":200,"ts":1542232426796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Grandmaster Flash & The Furious Five","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":429.63546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":584,"song":"The Message","status":200,"ts":1542232478796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Mich\u00c3\u0083\u00c2\u00a8le Arnaud","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":105.50812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":584,"song":"Chanson Sur Une Seule Note Samba De Uma Nota So","status":200,"ts":1542232907796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Prodigy","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":335.90812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"Breathe","status":200,"ts":1542234557796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Danny Gokey","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":187.08853,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"My Best Days Are Ahead Of Me","status":200,"ts":1542234892796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Queen","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":134.71302,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"Is This The World We Created? (1994 Digital Remaster)","status":200,"ts":1542235079796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Fratellis","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":196.25751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"Ole Black 'n' Blue Eyes","status":200,"ts":1542235213796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":208.92689,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"What I've Done (Album Version)","status":200,"ts":1542235409796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Silvio Rodriguez","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":381.3873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"Sue\u00c3\u0083\u00c2\u00b1o de Una Noche de Verano","status":200,"ts":1542235617796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Avantasia","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":582.73914,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"The Tower","status":200,"ts":1542235998796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Fleet Foxes","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":147.04281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"White Winter Hymnal","status":200,"ts":1542236580796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Asking Alexandria","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":278.83057,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"Not The American Average (feat. NO)","status":200,"ts":1542236727796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kanye West","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":242.93832,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"We Don't Care","status":200,"ts":1542237005796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":264.82893,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"Monsoon","status":200,"ts":1542237247796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Haddaway","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":223.97342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"What Is Love","status":200,"ts":1542237511796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Black Crowes","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":279.7971,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"Sting Me","status":200,"ts":1542237734796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Biz Markie","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":314.14812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"This Is Something for the Radio","status":200,"ts":1542238013796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Animal Collective","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":359.02649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"Brother Sport","status":200,"ts":1542238327796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":189.28281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":576,"song":"Given Up (Album Version)","status":200,"ts":1542238686796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"}
474.415755
693
0.697939
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Harmonia","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":655.77751,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":583,"song":"Sehr kosmisch","status":200,"ts":1542241826796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"The Prodigy","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":260.07465,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":583,"song":"The Big Gundown","status":200,"ts":1542242481796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Train","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":205.45261,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":583,"song":"Marry Me","status":200,"ts":1542242741796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":0,"lastName":"Scott","length":null,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"GET","page":"Home","registration":1540872073796.0,"sessionId":563,"song":null,"status":200,"ts":1542247071796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":null,"auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":0,"lastName":"Rosales","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1541059521796.0,"sessionId":521,"song":null,"status":200,"ts":1542252577796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"Sony Wonder","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":218.06975,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":597,"song":"Blackbird","status":200,"ts":1542253449796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":null,"auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":1,"lastName":"Gonzalez","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"About","registration":1540492941796.0,"sessionId":597,"song":null,"status":200,"ts":1542253460796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":602,"song":null,"status":307,"ts":1542260074796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":602,"song":null,"status":200,"ts":1542260277796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Van Halen","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":289.38404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":602,"song":"Best Of Both Worlds (Remastered Album Version)","status":200,"ts":1542260935796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Magic Sam","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":132.04853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":602,"song":"Call Me If You Need Me","status":200,"ts":1542261224796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Edward Sharpe & The Magnetic Zeros","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":306.31138,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":602,"song":"Home","status":200,"ts":1542261356796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Usher featuring will.i.am","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":395.72853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":602,"song":"OMG","status":200,"ts":1542261662796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":602,"song":null,"status":200,"ts":1542261713796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Helen Reddy","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":176.50893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":602,"song":"Candle On The Water","status":200,"ts":1542262057796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":201.06404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":602,"song":"Our Song","status":200,"ts":1542262233796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Sean Paul","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":245.34159,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":602,"song":"Baby Boy [feat. Beyonce]","status":200,"ts":1542262434796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Soundgarden","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Koch","length":272.19546,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":582,"song":"Black Hole Sun","status":200,"ts":1542262456796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Killers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":360.75057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":602,"song":"Human","status":200,"ts":1542262679796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Koch","length":165.11955,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":582,"song":"Addicted","status":200,"ts":1542262728796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Steve Anderson","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Koch","length":265.06404,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":582,"song":"Air","status":200,"ts":1542262893796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Rob Zombie","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Koch","length":220.13342,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":582,"song":"Superbeast","status":200,"ts":1542263158796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Deadmau5 & Kaskade","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Koch","length":595.56526,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":582,"song":"I Remember","status":200,"ts":1542263378796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":606,"song":null,"status":200,"ts":1542265424796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Shania Twain","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":213.7073,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":607,"song":"Don't Be Stupid (You Know I Love You)","status":200,"ts":1542265716796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Los Campesinos","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":138.10893,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":607,"song":"We throw parties_ you throw knives","status":200,"ts":1542265929796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Ill Nino","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":188.9171,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":606,"song":"How Can I Live (Spanish version) (Album Version)","status":200,"ts":1542266927796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Mia X","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":236.09424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":606,"song":"Thugs Like Me","status":200,"ts":1542267115796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Rage Against The Machine","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":314.40934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":606,"song":"Killing In The Name","status":200,"ts":1542267351796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Asia 2001","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":150.30812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":606,"song":"Epilogue","status":200,"ts":1542267665796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Muse","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":228.93669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":606,"song":"Endlessly","status":200,"ts":1542267815796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":591,"song":null,"status":200,"ts":1542267925796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Rise Against","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":221.17832,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":606,"song":"Torches","status":200,"ts":1542268043796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Upgrade","registration":1540511766796.0,"sessionId":591,"song":null,"status":200,"ts":1542268164796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":591,"song":null,"status":200,"ts":1542268187796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":3,"lastName":"Rodriguez","length":259.47383,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":591,"song":"The Good Times Are Killing Me","status":200,"ts":1542268205796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Marc Anthony","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":314.43546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":606,"song":"Te Conozco Bien","status":200,"ts":1542268264796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Regina Spektor","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":191.08526,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":606,"song":"The Calculation (Album Version)","status":200,"ts":1542268578796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Nina Sky","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":101.92934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Goodbye (Interlude)","status":200,"ts":1542274783796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":0,"lastName":"Watkins","length":236.09424,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Canada","status":200,"ts":1542275422796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":1,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1540871783796.0,"sessionId":324,"song":null,"status":200,"ts":1542275430796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Downgrade","registration":1540794356796.0,"sessionId":611,"song":null,"status":200,"ts":1542275437796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kudai","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":2,"lastName":"Watkins","length":256.62649,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Ven","status":200,"ts":1542275658796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Pulp","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":3,"lastName":"Watkins","length":260.8322,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Do You Remember The First Time?","status":200,"ts":1542275914796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Downgrade","registration":1540794356796.0,"sessionId":611,"song":null,"status":200,"ts":1542276099796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Sin\u00c3\u0083\u00c2\u00a9ad O'Connor","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":4,"lastName":"Watkins","length":282.51383,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"I Want Your (Hands On Me)","status":200,"ts":1542276174796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Paul Brown","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":232.54159,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Chill Out","status":200,"ts":1542276428796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Lasgo","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":5,"lastName":"Watkins","length":220.13342,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Something (Radio Edit)","status":200,"ts":1542276456796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Patty Loveless","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":188.13342,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"What's A Broken Heart","status":200,"ts":1542276660796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Eddie Vedder","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":6,"lastName":"Watkins","length":236.30322,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Society","status":200,"ts":1542276676796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Rogue Wave","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":234.13506,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Christians In Black","status":200,"ts":1542276848796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Muse","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":7,"lastName":"Watkins","length":304.84853,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Uprising","status":200,"ts":1542276912796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Amanda Blank","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":175.09832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Might Like You Better","status":200,"ts":1542277082796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Smiths","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":8,"lastName":"Watkins","length":162.24608,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Sheila Take A Bow","status":200,"ts":1542277216796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Old 97's","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":231.28771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Victoria (LP Version)","status":200,"ts":1542277257796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Selena","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":9,"lastName":"Watkins","length":316.42077,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Dreaming Of You","status":200,"ts":1542277378796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Fat Joe","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":267.10159,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"What's Luv? (Featuring Ja-Rule & Ashanti) (Explicit Album Version)","status":200,"ts":1542277488796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Stars","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":10,"lastName":"Watkins","length":193.33179,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Soft Revolution","status":200,"ts":1542277694796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"James Blunt","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":298.4224,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Same Mistake (Album Version)","status":200,"ts":1542277755796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mayday Parade","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":11,"lastName":"Watkins","length":203.28444,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Bruised And Scarred (Album Version)","status":200,"ts":1542277887796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Die Mooskirchner","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":169.29914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Frisch und g'sund","status":200,"ts":1542278053796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":12,"lastName":"Watkins","length":211.77424,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Rockit","status":200,"ts":1542278090796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Downgrade","registration":1540794356796.0,"sessionId":611,"song":null,"status":200,"ts":1542278172796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Toby Keith","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":208.48281,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Should've Been A Cowboy","status":200,"ts":1542278222796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":13,"lastName":"Watkins","length":284.18567,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Little Motel","status":200,"ts":1542278301796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Future Rock","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":239.90812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Gears","status":200,"ts":1542278430796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Noel Pointer","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":14,"lastName":"Watkins","length":259.7873,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Superwoman (Where Were You When I Needed You) (Digitally Remastered)","status":200,"ts":1542278585796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Callenish Circle","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":226.11546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Forgotten","status":200,"ts":1542278669796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":0,"lastName":"George","length":250.14812,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"Everlong","status":200,"ts":1542278704796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Portishead","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":15,"lastName":"Watkins","length":238.73261,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Hunter","status":200,"ts":1542278844796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":245.36771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"The Way I Loved You","status":200,"ts":1542278895796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"J-Live","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":1,"lastName":"George","length":256.93995,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"Longevity","status":200,"ts":1542278954796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The White Stripes","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":16,"lastName":"Watkins","length":110.47138,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Fell In Love With A Girl","status":200,"ts":1542279082796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":239.3073,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"You're The One","status":200,"ts":1542279140796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":17,"lastName":"Watkins","length":238.99383,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Lies","status":200,"ts":1542279192796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Five","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":2,"lastName":"George","length":207.62077,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"Got The Feelin'","status":200,"ts":1542279210796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":3,"lastName":"George","length":null,"level":"paid","location":"Birmingham-Hoover, AL","method":"GET","page":"Downgrade","registration":1541020249796.0,"sessionId":575,"song":null,"status":200,"ts":1542279284796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Ra","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":319.9473,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Do You Call My Name","status":200,"ts":1542279379796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Coolio feat. L.V.","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":4,"lastName":"George","length":241.57995,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"Gangsta's Paradise (LP Version)","status":200,"ts":1542279417796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Paramore","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":18,"lastName":"Watkins","length":211.51302,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Misery Business (Album Version)","status":200,"ts":1542279430796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Leggo Beast","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":19,"lastName":"Watkins","length":321.93261,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Itchy Feet","status":200,"ts":1542279641796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Nneka","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":5,"lastName":"George","length":226.79465,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"Gypsy","status":200,"ts":1542279658796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Diam's","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":18,"lastName":"Levine","length":250.72281,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Dans Ma Bulle (Edit Radio - Live 2006)","status":200,"ts":1542279698796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Haley Bonar","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":6,"lastName":"George","length":149.26322,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"Give It Up","status":200,"ts":1542279884796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Mansun","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":19,"lastName":"Levine","length":140.53832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Love Remains (Home Demo)","status":200,"ts":1542279948796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"3 Doors Down","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":20,"lastName":"Watkins","length":237.13914,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Here Without You","status":200,"ts":1542279962796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Corrs","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":7,"lastName":"George","length":168.07138,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"Toss The Feathers (Instrumental) ( LP Version )","status":200,"ts":1542280033796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Big Tymers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":20,"lastName":"Levine","length":197.79873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Big","status":200,"ts":1542280088796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Thursday","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":21,"lastName":"Watkins","length":215.37914,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"I Am The Killer (Album Version)","status":200,"ts":1542280199796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Motion City Soundtrack","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":8,"lastName":"George","length":111.49016,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"Don't Call It A Comeback (Album Version)","status":200,"ts":1542280201796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":9,"lastName":"George","length":null,"level":"paid","location":"Birmingham-Hoover, AL","method":"GET","page":"Help","registration":1541020249796.0,"sessionId":575,"song":null,"status":200,"ts":1542280260796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Usher","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":21,"lastName":"Levine","length":224.10404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Hey Daddy (Daddy's Home)","status":200,"ts":1542280285796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Juanes","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":10,"lastName":"George","length":233.40363,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"No Siento Penas","status":200,"ts":1542280312796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Wombats","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":22,"lastName":"Watkins","length":164.70159,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Kill The Director [Radio Edit]","status":200,"ts":1542280414796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Katy Perry","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":22,"lastName":"Levine","length":179.40853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"I Kissed A Girl","status":200,"ts":1542280509796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"As I Lay Dying","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":11,"lastName":"George","length":231.78404,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"The Darkest Nights","status":200,"ts":1542280545796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":23,"lastName":"Watkins","length":348.57751,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Undo","status":200,"ts":1542280578796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Bobby Fuller Four","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":23,"lastName":"Levine","length":138.60526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"I Fought The Law (LP Version)","status":200,"ts":1542280688796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Charly Garc\u00c3\u0083\u00c2\u00ada","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":12,"lastName":"George","length":330.89261,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"Influencia","status":200,"ts":1542280776796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"New Bomb Turks","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":24,"lastName":"Levine","length":60.55138,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Too Much","status":200,"ts":1542280826796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":25,"lastName":"Levine","length":196.91057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"All Hands Against His Own","status":200,"ts":1542280886796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"PeterLicht","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":24,"lastName":"Watkins","length":305.97179,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Blaues Blau","status":200,"ts":1542280926796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"John Mayer","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":26,"lastName":"Levine","length":359.23546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Friends_ Lovers Or Nothing","status":200,"ts":1542281082796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Stone Temple Pilots","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":13,"lastName":"George","length":255.32036,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"A Song For Sleeping (LP Version)","status":200,"ts":1542281106796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Bad Lieutenant","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":25,"lastName":"Watkins","length":266.84036,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Head Into Tomorrow","status":200,"ts":1542281231796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":14,"lastName":"George","length":192.49587,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"Smile Version Revisited (Mark Ronson Remix) (Explicit)","status":200,"ts":1542281361796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Neil Halstead","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":27,"lastName":"Levine","length":294.29506,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"A Gentle Heart","status":200,"ts":1542281441796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Juanes","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":26,"lastName":"Watkins","length":222.37995,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Un D\u00c3\u0083\u00c2\u00ada Normal","status":200,"ts":1542281497796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Distance","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":15,"lastName":"George","length":300.87791,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"Ska","status":200,"ts":1542281553796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Slipknot","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":27,"lastName":"Watkins","length":253.98812,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"The Heretic Anthem (Album Version)","status":200,"ts":1542281719796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":0,"lastName":"Cook","length":null,"level":"free","location":"Yuba City, CA","method":"GET","page":"Home","registration":1540679673796.0,"sessionId":560,"song":null,"status":200,"ts":1542281730796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Franz Ferdinand","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":28,"lastName":"Levine","length":137.56036,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Tell Her Tonight","status":200,"ts":1542281735796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jedi Mind Tricks","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":16,"lastName":"George","length":232.88118,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"Suicide","status":200,"ts":1542281853796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Miles Davis","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":29,"lastName":"Levine","length":285.20444,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Stella By Starlight","status":200,"ts":1542281872796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"B.o.B","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":28,"lastName":"Watkins","length":269.63546,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Nothin' On You [feat. Bruno Mars] (Album Version)","status":200,"ts":1542281972796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Avett Brothers","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":17,"lastName":"George","length":300.85179,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"I And Love And You","status":200,"ts":1542282085796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Joshua Bell \/ Paul Coker","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":30,"lastName":"Levine","length":275.93098,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Caprice viennois op.2","status":200,"ts":1542282157796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bad Brains","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":29,"lastName":"Watkins","length":32.31302,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Joshua's Song (1991 Digital Remaster)","status":200,"ts":1542282241796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Shakira ft. Wyclef Jean","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":30,"lastName":"Watkins","length":215.90159,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Hips Don't Lie","status":200,"ts":1542282273796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Band Of Horses","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":18,"lastName":"George","length":321.14893,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":575,"song":"The Funeral (Album Version)","status":200,"ts":1542282385796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Alesana","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":31,"lastName":"Levine","length":185.33832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Ambrosia","status":200,"ts":1542282432796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Samy Deluxe","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":31,"lastName":"Watkins","length":236.77342,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Einfach Ich","status":200,"ts":1542282488796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Corona","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":32,"lastName":"Levine","length":408.60689,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Higher Messiah","status":200,"ts":1542282617796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Presets","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":32,"lastName":"Watkins","length":267.54567,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"If I Know You","status":200,"ts":1542282724796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Pixies","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":33,"lastName":"Watkins","length":98.92526,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"In Heaven","status":200,"ts":1542282991796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Existone","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":33,"lastName":"Levine","length":652.30322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Wounded Soul","status":200,"ts":1542283025796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"John Mayer","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":34,"lastName":"Watkins","length":258.16771,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Bold As Love","status":200,"ts":1542283089796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Zakir Hussain","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":35,"lastName":"Watkins","length":722.442,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"The Great ndian Desert","status":200,"ts":1542283347796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Jag Panzer","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":34,"lastName":"Levine","length":200.38485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Face Of Fear","status":200,"ts":1542283677796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Two Door Cinema Club","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":35,"lastName":"Levine","length":189.67465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"What You Know","status":200,"ts":1542283877796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Little Anthony & The Imperials","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":36,"lastName":"Levine","length":127.42485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Hurt","status":200,"ts":1542284066796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Andr\u00c3\u0083\u00c2\u00a9s Cepeda","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":36,"lastName":"Watkins","length":211.80036,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Me Lleva Tiempo","status":200,"ts":1542284069796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Herb Alpert And The Tijuana Brass","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":37,"lastName":"Levine","length":132.80608,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"So What's New","status":200,"ts":1542284193796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Ozma","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":37,"lastName":"Watkins","length":144.53506,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Flight Of Yuri Gagarin","status":200,"ts":1542284280796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Ozric Tentacles","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":38,"lastName":"Levine","length":461.21751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Mooncalf","status":200,"ts":1542284325796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Evanescence","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":38,"lastName":"Watkins","length":263.78404,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"My Immortal (Album Version)","status":200,"ts":1542284424796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Weezer","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":39,"lastName":"Watkins","length":232.85506,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Velouria","status":200,"ts":1542284687796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Flying Lotus","auth":"Logged In","firstName":"Jahiem","gender":"M","itemInSession":0,"lastName":"Miles","length":115.33016,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540817347796.0,"sessionId":369,"song":"Bad Actors","status":200,"ts":1542284714796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"43"} {"artist":"Ben Folds","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":39,"lastName":"Levine","length":250.87955,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Bitches Ain't Shit","status":200,"ts":1542284786796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"matchbox twenty","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":40,"lastName":"Watkins","length":229.14567,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Unwell (Album Version)","status":200,"ts":1542284919796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Deftones","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":40,"lastName":"Levine","length":189.75302,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Feiticeira (LP Version)","status":200,"ts":1542285036796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":615,"song":null,"status":200,"ts":1542285072796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"Logout","registration":1540940782796.0,"sessionId":615,"song":null,"status":307,"ts":1542285073796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":536,"song":null,"status":200,"ts":1542285134796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Silverchair","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":41,"lastName":"Watkins","length":319.13751,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Without You (Album Version)","status":200,"ts":1542285148796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Muse","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":41,"lastName":"Levine","length":258.06322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"Map Of The Problematique","status":200,"ts":1542285225796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Zen Caf\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":42,"lastName":"Watkins","length":259.02975,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Kotona kaikuu","status":200,"ts":1542285467796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Mariah Carey \/ Twista","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":42,"lastName":"Levine","length":194.7424,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":611,"song":"One And Only","status":200,"ts":1542285483796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":615,"song":null,"status":200,"ts":1542285613796,"userAgent":null,"userId":""} {"artist":"Strike Anywhere","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":43,"lastName":"Watkins","length":120.00608,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Gunpowder","status":200,"ts":1542285726796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Tri Sestry","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":44,"lastName":"Watkins","length":97.72363,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Had Stupid","status":200,"ts":1542285846796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Don Williams","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":45,"lastName":"Watkins","length":191.03302,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"If Hollywood Don't Need You","status":200,"ts":1542285943796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Nerves","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":46,"lastName":"Watkins","length":92.86485,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Are You Famous?","status":200,"ts":1542286134796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Ulf Wakenius","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":47,"lastName":"Watkins","length":324.15302,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Good Morning Susie Soho","status":200,"ts":1542286226796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Kooks","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":48,"lastName":"Watkins","length":168.72444,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"She Moves In Her Own Way","status":200,"ts":1542286550796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"New Radicals","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":49,"lastName":"Watkins","length":300.82567,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"You Get What You Give","status":200,"ts":1542286718796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Wolfmother","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":50,"lastName":"Watkins","length":333.7922,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Where Eagles Have Been","status":200,"ts":1542287018796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Shins","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":51,"lastName":"Watkins","length":225.61914,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Spilt Needles (Album)","status":200,"ts":1542287351796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Nickel Creek","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":52,"lastName":"Watkins","length":248.58077,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Reasons Why","status":200,"ts":1542287576796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Pigeon John","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":53,"lastName":"Watkins","length":180.00934,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Crazy","status":200,"ts":1542287824796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Eels","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":54,"lastName":"Watkins","length":211.48689,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Love Of The Loveless","status":200,"ts":1542288004796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Harmonia","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":55,"lastName":"Watkins","length":655.77751,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Sehr kosmisch","status":200,"ts":1542288215796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Marina And The Diamonds","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":56,"lastName":"Watkins","length":182.59546,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Oh No! (album version)","status":200,"ts":1542288870796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Eminem","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":57,"lastName":"Watkins","length":284.86485,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"The Real Slim Shady","status":200,"ts":1542289052796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Hassisen Kone","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":58,"lastName":"Watkins","length":162.61179,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"REIPPAINA K\u00c3\u0083\u00c2\u0084YMME REKKAIN ALLE","status":200,"ts":1542289336796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":59,"lastName":"Watkins","length":239.3073,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"You're The One","status":200,"ts":1542289498796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Sunlounger","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":60,"lastName":"Watkins","length":594.15465,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"White Sand","status":200,"ts":1542289737796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Youssou N'Dour","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":61,"lastName":"Watkins","length":238.39302,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Tan bi (Heat_ Breeze_ Tenderness) \/ Chaleur_ brise_ tendress","status":200,"ts":1542290331796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Decemberists","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":62,"lastName":"Watkins","length":209.08363,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Red Right Ankle","status":200,"ts":1542290569796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Ruts","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":63,"lastName":"Watkins","length":185.75628,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Savage Circle","status":200,"ts":1542290778796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Adrian Legg","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":64,"lastName":"Watkins","length":122.77506,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"The One-Eyed Turk","status":200,"ts":1542290963796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":65,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1540871783796.0,"sessionId":324,"song":null,"status":200,"ts":1542290965796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Bedrock","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":66,"lastName":"Watkins","length":664.0322,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Set In Stone","status":200,"ts":1542291085796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Prince & The Revolution","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":280.00608,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Let's Go Crazy (LP Version)","status":200,"ts":1542291150796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Zombies","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":157.33506,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"She's Coming Home","status":200,"ts":1542291430796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Portishead","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":238.0273,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Numb","status":200,"ts":1542291587796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":67,"lastName":"Watkins","length":212.68853,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Breakdown","status":200,"ts":1542291749796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Justice","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":205.50485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Let There Be Lite (Album Version)","status":200,"ts":1542291825796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Snow Patrol","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":68,"lastName":"Watkins","length":223.18975,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Set Down Your Glass","status":200,"ts":1542291961796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":613,"song":null,"status":200,"ts":1542291989796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Lemon Jelly","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":238.47138,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Nice Weather For Ducks","status":200,"ts":1542292030796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Lucksmiths","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":69,"lastName":"Watkins","length":153.70404,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Tale Of Two Cities","status":200,"ts":1542292184796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Ben Kweller","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":188.60363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Magic","status":200,"ts":1542292268796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Fedde le Grand Pres. Flamingo","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":70,"lastName":"Watkins","length":396.32934,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Take No Shhh (Original Mix)","status":200,"ts":1542292337796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Rodrigo y Gabriela","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":233.40363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"VIKING MAN","status":200,"ts":1542292456796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":289.12281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"I Gotta Feeling","status":200,"ts":1542292689796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":71,"lastName":"Watkins","length":236.09424,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Canada","status":200,"ts":1542292733796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":164.57098,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":598,"song":"Down On The Corner","status":200,"ts":1542292773796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":186.69669,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":598,"song":"Camaro","status":200,"ts":1542292937796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Fireflight","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":72,"lastName":"Watkins","length":201.16853,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Unbreakable","status":200,"ts":1542292969796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Steppenwolf","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":208.14322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Born To Be Wild","status":200,"ts":1542292978796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"New Found Glory","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":2,"lastName":"Robinson","length":222.69342,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":598,"song":"the king of wishful thinking","status":200,"ts":1542293123796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":null,"auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":0,"lastName":"Larson","length":null,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Home","registration":1541045604796.0,"sessionId":531,"song":null,"status":200,"ts":1542293159796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"The Pussycat Dolls","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":73,"lastName":"Watkins","length":221.1522,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Elevator","status":200,"ts":1542293170796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Eric Clapton","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":208.48281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Willie And The Hand Jive","status":200,"ts":1542293186796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Josh Groban","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":1,"lastName":"Larson","length":260.70159,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":531,"song":"Little Drummer Boy [featuring guitarist Andy McKee] (Album Version)","status":200,"ts":1542293243796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"The Dresden Dolls","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":74,"lastName":"Watkins","length":286.40608,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Coin-Operated Boy","status":200,"ts":1542293391796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Pixies","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":229.3024,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Where Is My Mind?","status":200,"ts":1542293394796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":2,"lastName":"Larson","length":271.882,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":531,"song":"I Put A Spell On You","status":200,"ts":1542293503796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"The Smiths","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":123.01016,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Girlfriend In A Coma","status":200,"ts":1542293623796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Danger Doom","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":75,"lastName":"Watkins","length":187.27138,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"No Names (Black Debbie) (Album Version)","status":200,"ts":1542293677796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":12,"lastName":"Harrell","length":233.89995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Love Story","status":200,"ts":1542293746796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Vilma Palma e Vampiros","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":76,"lastName":"Watkins","length":281.99138,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"La pachanga","status":200,"ts":1542293864796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Busta Rhymes feat. Pharrell","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":13,"lastName":"Harrell","length":220.47302,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Light Your Ass On Fire","status":200,"ts":1542293979796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Little People","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":77,"lastName":"Watkins","length":230.1122,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Above The Clouds","status":200,"ts":1542294145796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":14,"lastName":"Harrell","length":239.3073,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"You're The One","status":200,"ts":1542294199796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":78,"lastName":"Watkins","length":164.85832,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"He Can Only Hold Her","status":200,"ts":1542294375796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Ernie K-Doe","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":15,"lastName":"Harrell","length":160.96608,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Te-Ta-Te-Ta-Ta (2002 Digital Remaster)","status":200,"ts":1542294438796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Alesana","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":79,"lastName":"Watkins","length":242.49424,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Congratulations_ I Hate You","status":200,"ts":1542294539796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":16,"lastName":"Harrell","length":239.3073,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"You're The One","status":200,"ts":1542294598796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Gazpacho","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":80,"lastName":"Watkins","length":253.51791,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Premonicion","status":200,"ts":1542294781796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Black Lips","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":17,"lastName":"Harrell","length":162.76853,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Lock and Key","status":200,"ts":1542294837796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kanye West","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":18,"lastName":"Harrell","length":311.84934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Stronger","status":200,"ts":1542294999796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Arcade Fire","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":81,"lastName":"Watkins","length":136.69832,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Neon Bible","status":200,"ts":1542295034796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":82,"lastName":"Watkins","length":277.15873,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1542295170796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Fanfarlo","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":19,"lastName":"Harrell","length":270.78485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"I'm a Pilot","status":200,"ts":1542295310796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Crystal Castles","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":83,"lastName":"Watkins","length":251.08853,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Empathy","status":200,"ts":1542295447796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":84,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"About","registration":1540871783796.0,"sessionId":324,"song":null,"status":200,"ts":1542295448796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":85,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"About","registration":1540871783796.0,"sessionId":324,"song":null,"status":200,"ts":1542295477796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Zeca Baleiro","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":20,"lastName":"Harrell","length":452.8322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Brigitte Bardot","status":200,"ts":1542295580796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Angus & Julia Stone","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":86,"lastName":"Watkins","length":236.95628,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Just A Boy","status":200,"ts":1542295698796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Julian Casablancas","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":87,"lastName":"Watkins","length":302.47138,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"4 Chords of the Apocalypse","status":200,"ts":1542295934796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Fat Joe","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":21,"lastName":"Harrell","length":241.34485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Safe 2 Say [The Incredible] (Album Version - Amended)","status":200,"ts":1542296032796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Usher Featuring Lil' Jon & Ludacris","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":88,"lastName":"Watkins","length":250.38322,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Yeah!","status":200,"ts":1542296236796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Pat Benatar","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":22,"lastName":"Harrell","length":290.37669,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Don't Walk Away","status":200,"ts":1542296273796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Fergie","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":89,"lastName":"Watkins","length":248.39791,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Losing My Ground","status":200,"ts":1542296486796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Muse","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":23,"lastName":"Harrell","length":209.50159,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Supermassive Black Hole (Twilight Soundtrack Version)","status":200,"ts":1542296563796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Two Door Cinema Club","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":90,"lastName":"Watkins","length":168.09751,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Undercover Martyn","status":200,"ts":1542296734796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Spineshank","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":24,"lastName":"Harrell","length":167.26159,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Intake (Album Version)","status":200,"ts":1542296772796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Whitney Houston Duet With Mariah Carey","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":91,"lastName":"Watkins","length":273.34485,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"When You Believe","status":200,"ts":1542296902796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Death Cab for Cutie","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":25,"lastName":"Harrell","length":488.64608,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Transatlanticism","status":200,"ts":1542296939796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Noir D\u00c3\u0083\u00c2\u00a9sir","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":92,"lastName":"Watkins","length":374.77832,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Ces Gens L\u00c3\u0083\u00c2\u00a0","status":200,"ts":1542297175796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Paramore","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":26,"lastName":"Harrell","length":243.51302,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Emergency (Album Version)","status":200,"ts":1542297427796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"My Chemical Romance","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":93,"lastName":"Watkins","length":188.05506,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Cemetery Drive (Album Version)","status":200,"ts":1542297549796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Vincent Vincent And The Villains","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":27,"lastName":"Harrell","length":154.64444,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"On My Own","status":200,"ts":1542297670796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Phoenix","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":94,"lastName":"Watkins","length":229.79873,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Run Run Run","status":200,"ts":1542297737796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":28,"lastName":"Harrell","length":193.54077,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Skills To Pay The Bills","status":200,"ts":1542297824796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Natasha Bedingfield","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":216.65914,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":554,"song":"These Words","status":200,"ts":1542297880796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Calle 13","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":95,"lastName":"Watkins","length":239.3073,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Atr\u00c3\u0083\u00c2\u00a9vete te te","status":200,"ts":1542297966796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Sondre Lerche","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":29,"lastName":"Harrell","length":215.71873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Modern Nature","status":200,"ts":1542298017796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Cecilia","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":157.77914,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":554,"song":"Ultimo Baile","status":200,"ts":1542298096796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Air","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":96,"lastName":"Watkins","length":258.58567,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Mayfair Song","status":200,"ts":1542298205796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":30,"lastName":"Harrell","length":236.09424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Canada","status":200,"ts":1542298232796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kings Of Convenience","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Burns","length":245.02812,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":554,"song":"Riot On An Empty Street","status":200,"ts":1542298253796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":621,"song":null,"status":200,"ts":1542298335796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":621,"song":null,"status":307,"ts":1542298336796,"userAgent":null,"userId":""} {"artist":"Rhonda Vincent","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":97,"lastName":"Watkins","length":142.78485,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"You're In My Heart","status":200,"ts":1542298463796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Soulwax","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":31,"lastName":"Harrell","length":277.002,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"E Talking","status":200,"ts":1542298468796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Red","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Burns","length":227.52608,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":554,"song":"Mystery of You","status":200,"ts":1542298498796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Sugababes","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":98,"lastName":"Watkins","length":275.93098,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Overload","status":200,"ts":1542298605796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Eminem \/ Dr. Dre","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Burns","length":309.83791,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":554,"song":"Say What You Say","status":200,"ts":1542298725796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Michael Jackson","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":32,"lastName":"Harrell","length":278.282,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Scream","status":200,"ts":1542298745796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":621,"song":null,"status":200,"ts":1542298772796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dominique A","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":99,"lastName":"Watkins","length":153.20771,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Le Courage Des Oiseaux","status":200,"ts":1542298880796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":33,"lastName":"Harrell","length":259.86567,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"My December","status":200,"ts":1542299023796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":100,"lastName":"Watkins","length":236.09424,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Canada","status":200,"ts":1542299033796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Dear Nora","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":101,"lastName":"Watkins","length":59.66322,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Give Me Some Of Yr Love","status":200,"ts":1542299269796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Police","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":34,"lastName":"Harrell","length":290.24608,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Message In A Bottle","status":200,"ts":1542299282796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Cocoon","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":102,"lastName":"Watkins","length":159.97342,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Microwave","status":200,"ts":1542299328796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Coldplay","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":0,"lastName":"Williams","length":349.93587,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":485,"song":"A Rush Of Blood To The Head","status":200,"ts":1542299400796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Peter And Gordon","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":0,"lastName":"Burke","length":161.14893,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":526,"song":"A World Without Love","status":200,"ts":1542299477796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"Gotye","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":103,"lastName":"Watkins","length":360.33261,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Coming Back","status":200,"ts":1542299487796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Maps","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":35,"lastName":"Harrell","length":255.9473,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"To The Sky","status":200,"ts":1542299572796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Joshua Radin","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":1,"lastName":"Burke","length":169.32526,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":526,"song":"I'd Rather Be With You","status":200,"ts":1542299638796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"D'Angelo","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":344.94649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":621,"song":"When We Get By","status":200,"ts":1542299658796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Blockhead","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":1,"lastName":"Williams","length":289.56689,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":485,"song":"The Music Scene","status":200,"ts":1542299749796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Nine Inch Nails","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":300.64281,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":588,"song":"Terrible Lie","status":200,"ts":1542299805796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"La Roux","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":2,"lastName":"Burke","length":208.03873,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":526,"song":"Colourless Colour","status":200,"ts":1542299807796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"Lil Wayne \/ Shanell","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":36,"lastName":"Harrell","length":216.81587,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"American Star","status":200,"ts":1542299827796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"R\u00c3\u0083\u00c2\u00b6yksopp","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":104,"lastName":"Watkins","length":300.14649,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"What Else Is There?","status":200,"ts":1542299847796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Jack's Mannequin","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":172.90404,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":621,"song":"Spinning (Album Version)","status":200,"ts":1542300002796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"FM Static","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":37,"lastName":"Harrell","length":170.81424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Definitely Maybe","status":200,"ts":1542300043796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Joy Division","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":105,"lastName":"Watkins","length":209.03138,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Disorder [2007 Re-mastered Album Version]","status":200,"ts":1542300147796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"N.E.R.D.","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":259.23873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":621,"song":"Rock Star","status":200,"ts":1542300174796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Mickie Krause","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":38,"lastName":"Harrell","length":204.17261,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Orange Tr\u00c3\u0083\u00c2\u00a4gt Nur Die M\u00c3\u0083\u00c2\u00bcllabfuhr (Go West)","status":200,"ts":1542300213796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Steadman","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":106,"lastName":"Watkins","length":234.1873,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Wave Goodbye (Real\/Rhapsody Version)","status":200,"ts":1542300356796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Like","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":39,"lastName":"Harrell","length":245.68118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"We Are Lost","status":200,"ts":1542300417796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Future Rock","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":239.90812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":621,"song":"Gears","status":200,"ts":1542300433796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":0,"lastName":"Barrett","length":null,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540685364796.0,"sessionId":404,"song":null,"status":200,"ts":1542300491796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":1,"lastName":"Barrett","length":213.08036,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Gives You Hell","status":200,"ts":1542300503796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Bruce Springsteen","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":107,"lastName":"Watkins","length":270.54975,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Born To Run","status":200,"ts":1542300590796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":40,"lastName":"Harrell","length":230.63465,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Say (All I Need)","status":200,"ts":1542300662796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Owl City","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":133.74649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":621,"song":"Meteor Shower","status":200,"ts":1542300672796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Justin Nozuka","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":2,"lastName":"Barrett","length":215.64036,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"I'm In Peace","status":200,"ts":1542300716796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Marina And The Diamonds","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":262.97424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":621,"song":"I Am Not a Robot","status":200,"ts":1542300805796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Serendipity Singers","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":108,"lastName":"Watkins","length":163.21261,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"Don't Let The Rain Come Down (Crooked Little Man)","status":200,"ts":1542300860796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Haujobb","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":41,"lastName":"Harrell","length":225.12281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Maternal Instinct","status":200,"ts":1542300892796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Cyndi Lauper","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":3,"lastName":"Barrett","length":156.96934,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"My Baby Just Cares For Me","status":200,"ts":1542300931796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Usher featuring will.i.am","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":109,"lastName":"Watkins","length":395.72853,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"OMG","status":200,"ts":1542301023796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Depeche Mode","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":397.42649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":621,"song":"Everything Counts (Live) (Single Version)","status":200,"ts":1542301067796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Red Hot Chili Peppers","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":4,"lastName":"Barrett","length":240.32608,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Especially In Michigan (Album Version)","status":200,"ts":1542301087796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"3 Doors Down","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":42,"lastName":"Harrell","length":233.74322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Kryptonite","status":200,"ts":1542301117796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Newbeats","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":5,"lastName":"Barrett","length":109.24363,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Bread And Butter","status":200,"ts":1542301327796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":null,"auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":6,"lastName":"Barrett","length":null,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Settings","registration":1540685364796.0,"sessionId":404,"song":null,"status":200,"ts":1542301347796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":43,"lastName":"Harrell","length":260.38812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Dusty","status":200,"ts":1542301350796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Los Lobos","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":110,"lastName":"Watkins","length":174.18404,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"La Bamba","status":200,"ts":1542301418796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Drake \/ Kanye West \/ Lil Wayne \/ Eminem","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":7,"lastName":"Barrett","length":357.66812,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Forever","status":200,"ts":1542301436796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Ginuwine","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":244.27057,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":621,"song":"I'm In Love","status":200,"ts":1542301464796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Descendents","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":111,"lastName":"Watkins","length":89.23383,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":324,"song":"I'm Not A Loser","status":200,"ts":1542301592796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":112,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"Logout","registration":1540871783796.0,"sessionId":324,"song":null,"status":307,"ts":1542301593796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":113,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":324,"song":null,"status":200,"ts":1542301604796,"userAgent":null,"userId":""} {"artist":"Jennifer Love Hewitt","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":44,"lastName":"Harrell","length":222.17098,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"BareNaked","status":200,"ts":1542301610796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Cinematic Orchestra","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":613.74649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":621,"song":"Burn Out","status":200,"ts":1542301708796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"Logout","registration":1540940782796.0,"sessionId":621,"song":null,"status":307,"ts":1542301709796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"La Fuga","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":8,"lastName":"Barrett","length":217.70404,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Baja por diversion (directo 05)","status":200,"ts":1542301793796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Killswitch Engage","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":45,"lastName":"Harrell","length":259.89179,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Hope Is... (Album Version)","status":200,"ts":1542301832796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kid Cudi Vs Crookers","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":9,"lastName":"Barrett","length":162.97751,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Day 'N' Nite","status":200,"ts":1542302010796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":13,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":621,"song":null,"status":200,"ts":1542302058796,"userAgent":null,"userId":""} {"artist":"Beirut","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":46,"lastName":"Harrell","length":213.68118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"La Llorona","status":200,"ts":1542302091796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Fall Out Boy","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":10,"lastName":"Barrett","length":181.36771,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Dance_ Dance","status":200,"ts":1542302172796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Christina Aguilera \/ Lil' Kim \/ Mya \/ Pink","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":47,"lastName":"Harrell","length":264.93342,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Lady Marmalade","status":200,"ts":1542302304796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Harold Budd","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":11,"lastName":"Barrett","length":392.85506,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Algebra Of Darkness (Album Version)","status":200,"ts":1542302353796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Eric Burdon & War","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":48,"lastName":"Harrell","length":281.93914,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Jimbo (Album Version)","status":200,"ts":1542302568796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Cass McCombs","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":12,"lastName":"Barrett","length":234.13506,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Deseret","status":200,"ts":1542302745796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":49,"lastName":"Harrell","length":139.51955,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"I'll Be Your Man","status":200,"ts":1542302849796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Leona Naess","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":13,"lastName":"Barrett","length":223.03302,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Christmas","status":200,"ts":1542302979796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":50,"lastName":"Harrell","length":252.21179,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1542302988796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":51,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"Logout","registration":1540472624796.0,"sessionId":605,"song":null,"status":307,"ts":1542302989796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":52,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":605,"song":null,"status":200,"ts":1542303072796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":53,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":605,"song":null,"status":307,"ts":1542303073796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":54,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":605,"song":null,"status":200,"ts":1542303127796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Nando Reis","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":14,"lastName":"Barrett","length":254.6673,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"A Letra \"A","status":200,"ts":1542303202796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Kris Allen","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":55,"lastName":"Harrell","length":212.50567,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Live Like We're Dying","status":200,"ts":1542303240796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Muse","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":56,"lastName":"Harrell","length":224.44363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Muscle Museum (Soulwax Remix)","status":200,"ts":1542303452796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Goldfrapp","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":15,"lastName":"Barrett","length":228.0224,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Lovely Head","status":200,"ts":1542303456796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Slash","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":57,"lastName":"Harrell","length":189.23057,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Doctor Alibi (featuring Lemmy Kilmister)","status":200,"ts":1542303676796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"D.R.I.","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":16,"lastName":"Barrett","length":66.61179,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Stupid_ Stupid War (Dealing With It)","status":200,"ts":1542303684796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":17,"lastName":"Barrett","length":211.722,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Unite (2009 Digital Remaster)","status":200,"ts":1542303750796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Cat Power","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":58,"lastName":"Harrell","length":218.3571,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Hate","status":200,"ts":1542303865796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":18,"lastName":"Barrett","length":201.79546,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Revelry","status":200,"ts":1542303961796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Hot Water Music","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":59,"lastName":"Harrell","length":201.40363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Translocation","status":200,"ts":1542304083796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Miranda Lambert","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":19,"lastName":"Barrett","length":251.61098,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Me And Charlie Talking","status":200,"ts":1542304162796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Brandy duet with Monica","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":60,"lastName":"Harrell","length":294.79138,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"The Boy Is Mine (Duet With Monica) (LP Version)","status":200,"ts":1542304284796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Heavy","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":20,"lastName":"Barrett","length":197.35465,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"How You Like Me Now?","status":200,"ts":1542304413796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Streetlight Manifesto","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":61,"lastName":"Harrell","length":327.91465,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Point\/Counterpoint (Album Version)","status":200,"ts":1542304578796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Blitzen Trapper","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":21,"lastName":"Barrett","length":171.15383,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Murder Babe (Album)","status":200,"ts":1542304610796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Megan McCauley","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":22,"lastName":"Barrett","length":228.57098,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Die For You","status":200,"ts":1542304781796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":62,"lastName":"Harrell","length":207.64689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Better Together","status":200,"ts":1542304905796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Passion Pit","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":23,"lastName":"Barrett","length":243.69587,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Eyes As Candles","status":200,"ts":1542305009796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Strunz & Farah","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":315.32363,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Zagros","status":200,"ts":1542305057796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Minus The Bear","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":63,"lastName":"Harrell","length":230.45179,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Part 2","status":200,"ts":1542305112796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Van Halen","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":24,"lastName":"Barrett","length":102.5824,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Eruption (Album Version)","status":200,"ts":1542305252796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Pavement","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":64,"lastName":"Harrell","length":149.83791,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Heaven Is A Truck","status":200,"ts":1542305342796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":25,"lastName":"Barrett","length":195.94404,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Sincerit\u00c3\u0083\u00c2\u00a9 Et Jalousie","status":200,"ts":1542305354796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Pieces Of A Dream","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":311.562,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Keep It Smooth","status":200,"ts":1542305372796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":65,"lastName":"Harrell","length":315.42812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Born On The Bayou","status":200,"ts":1542305491796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Anouk","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":26,"lastName":"Barrett","length":268.5122,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"It's So Hard","status":200,"ts":1542305549796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Jaco Pastorius Big Band","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":69.3024,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Amerika (Album Version)","status":200,"ts":1542305683796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Avril Lavigne","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":3,"lastName":"Kirby","length":222.9024,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"I'm With You","status":200,"ts":1542305752796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Gonzalo Rubalcaba","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":66,"lastName":"Harrell","length":525.47873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Circuito III","status":200,"ts":1542305806796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":27,"lastName":"Barrett","length":348.57751,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Undo","status":200,"ts":1542305817796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Ska-P","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":4,"lastName":"Kirby","length":298.13506,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Casposos","status":200,"ts":1542305974796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Strokes","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":28,"lastName":"Barrett","length":155.34975,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Is This It","status":200,"ts":1542306165796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Jesse Belvin","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":5,"lastName":"Kirby","length":184.63302,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Goodnight My Love","status":200,"ts":1542306272796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":6,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Help","registration":1541022995796.0,"sessionId":619,"song":null,"status":200,"ts":1542306275796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":29,"lastName":"Barrett","length":265.76934,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Creil City","status":200,"ts":1542306320796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"The Gerbils","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":67,"lastName":"Harrell","length":27.01016,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"(iii)","status":200,"ts":1542306331796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"KJ-52","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":68,"lastName":"Harrell","length":275.77424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Life After Death","status":200,"ts":1542306358796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Mariah Carey","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":7,"lastName":"Kirby","length":242.96444,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"All I Want For Christmas Is You","status":200,"ts":1542306456796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Glen Hansard & Marketa Irglova","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":30,"lastName":"Barrett","length":282.67057,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"The Moon (Album version)","status":200,"ts":1542306585796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Dion & The Belmonts","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":69,"lastName":"Harrell","length":152.31955,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"A Teenager In Love","status":200,"ts":1542306633796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Kynnedi","gender":"F","itemInSession":0,"lastName":"Sanchez","length":236.93016,"level":"free","location":"Cedar Rapids, IA","method":"PUT","page":"NextSong","registration":1541079034796.0,"sessionId":600,"song":"Bubble Toes","status":200,"ts":1542306652796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_8_5) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"89"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":8,"lastName":"Kirby","length":172.22485,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"The Maestro","status":200,"ts":1542306698796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Lesley Gore","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":70,"lastName":"Harrell","length":134.37342,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"It's My Party","status":200,"ts":1542306785796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Dr. Dre \/ Snoop Dogg","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":31,"lastName":"Barrett","length":161.51465,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"The Next Episode","status":200,"ts":1542306867796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Pearl Jam","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":9,"lastName":"Kirby","length":67.44771,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Encore Break","status":200,"ts":1542306870796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Cake","auth":"Logged In","firstName":"Kynnedi","gender":"F","itemInSession":1,"lastName":"Sanchez","length":179.09506,"level":"free","location":"Cedar Rapids, IA","method":"PUT","page":"NextSong","registration":1541079034796.0,"sessionId":600,"song":"Commissioning A Symphony In C","status":200,"ts":1542306888796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_8_5) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"89"} {"artist":"Phoenix","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":71,"lastName":"Harrell","length":278.07302,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Rome","status":200,"ts":1542306919796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Alesana","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":10,"lastName":"Kirby","length":285.51791,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Seduction (album)","status":200,"ts":1542306937796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Kooks","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":32,"lastName":"Barrett","length":168.72444,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"She Moves In Her Own Way","status":200,"ts":1542307028796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Dakis","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":33,"lastName":"Barrett","length":162.48118,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"La Petite Marie (2005 Digital Remaster)","status":200,"ts":1542307196796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Limp Bizkit","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":72,"lastName":"Harrell","length":214.5171,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Rollin' (Air Raid Vehicle)","status":200,"ts":1542307197796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"JET","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":11,"lastName":"Kirby","length":261.3024,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Move On (Album Version)","status":200,"ts":1542307222796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Mickie Krause","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":34,"lastName":"Barrett","length":204.17261,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Orange Tr\u00c3\u0083\u00c2\u00a4gt Nur Die M\u00c3\u0083\u00c2\u00bcllabfuhr (Go West)","status":200,"ts":1542307358796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Hot Chip","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":73,"lastName":"Harrell","length":314.69669,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"My Piano (DJ-Kicks)","status":200,"ts":1542307411796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Yung Berg","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":12,"lastName":"Kirby","length":230.63465,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Do That There (featuring Dude 'N Nem)","status":200,"ts":1542307483796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":35,"lastName":"Barrett","length":237.53098,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Closer","status":200,"ts":1542307562796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Johan","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":13,"lastName":"Kirby","length":190.27546,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Life On Mars","status":200,"ts":1542307713796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Crystal Castles","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":74,"lastName":"Harrell","length":138.91873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Love And Caring","status":200,"ts":1542307725796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":75,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":605,"song":null,"status":200,"ts":1542307748796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Thirteen Senses","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":36,"lastName":"Barrett","length":286.45832,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Lead Us","status":200,"ts":1542307799796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Eisbrecher","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":76,"lastName":"Harrell","length":241.89342,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Adrenalin","status":200,"ts":1542307863796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Buckcherry","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":14,"lastName":"Kirby","length":201.79546,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Crazy Bitch (Album Version)","status":200,"ts":1542307903796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Band Of Horses","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":37,"lastName":"Barrett","length":187.0624,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"The General Specific (Album)","status":200,"ts":1542308085796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Darkseed","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":77,"lastName":"Harrell","length":250.33098,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Speak Silence","status":200,"ts":1542308104796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Caetano Veloso","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":15,"lastName":"Kirby","length":223.97342,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"O Samba E O Tango","status":200,"ts":1542308104796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Maria Arredondo","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":38,"lastName":"Barrett","length":243.74812,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Burning","status":200,"ts":1542308272796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Boyzone","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":16,"lastName":"Kirby","length":219.81995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"All That I Need","status":200,"ts":1542308327796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":78,"lastName":"Harrell","length":273.47546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Trouble","status":200,"ts":1542308354796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"matchbox twenty","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":39,"lastName":"Barrett","length":229.14567,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Unwell (Album Version)","status":200,"ts":1542308515796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Sussie 4","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":17,"lastName":"Kirby","length":331.33669,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"On Time","status":200,"ts":1542308546796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Klaxons","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":79,"lastName":"Harrell","length":166.79138,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Golden Skans","status":200,"ts":1542308627796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Prince","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":40,"lastName":"Barrett","length":340.71465,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Hot Thing ( LP Version )","status":200,"ts":1542308744796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":80,"lastName":"Harrell","length":239.3073,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"You're The One","status":200,"ts":1542308793796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Damian Marley \/ Capleton \/ Drag-On \/ Stephen Marley","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":18,"lastName":"Kirby","length":361.03791,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"It Was Written","status":200,"ts":1542308877796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Markus Kruneg\u00c3\u0083\u00c2\u00a5rd","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":81,"lastName":"Harrell","length":185.5473,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Genom tunna tyger","status":200,"ts":1542309032796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kamera","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":41,"lastName":"Barrett","length":221.33506,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"I Was Made","status":200,"ts":1542309084796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Rainer Weichhold vs. Dandi & Ugo","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":82,"lastName":"Harrell","length":397.66159,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Infinite Template","status":200,"ts":1542309217796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Sondre Lerche","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":19,"lastName":"Kirby","length":136.98567,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Face The Blood","status":200,"ts":1542309238796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"John Mayer","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":42,"lastName":"Barrett","length":241.99791,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Slow Dancing In A Burning Room","status":200,"ts":1542309305796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Mystikal","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":20,"lastName":"Kirby","length":234.89261,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Alright","status":200,"ts":1542309374796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Luis Fonsi","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":43,"lastName":"Barrett","length":278.17751,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Aunque Estes Con El","status":200,"ts":1542309546796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Angelic Upstarts","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":21,"lastName":"Kirby","length":144.74404,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Two Million Voices","status":200,"ts":1542309608796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Tonic","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":83,"lastName":"Harrell","length":228.38812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Count On Me (Somebody)","status":200,"ts":1542309614796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Enya","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":22,"lastName":"Kirby","length":259.86567,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Exile","status":200,"ts":1542309752796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":44,"lastName":"Barrett","length":277.83791,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Everyone's At It","status":200,"ts":1542309824796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Lissi Dancefloor Disaster","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":84,"lastName":"Harrell","length":246.12526,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"I'M Gonna Keep On Driving My Car","status":200,"ts":1542309842796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":45,"lastName":"Barrett","length":null,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Settings","registration":1540685364796.0,"sessionId":404,"song":null,"status":200,"ts":1542309845796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"M.I.A.","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":23,"lastName":"Kirby","length":206.13179,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Paper Planes","status":200,"ts":1542310011796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"India.Arie","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":85,"lastName":"Harrell","length":245.26322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Interested","status":200,"ts":1542310088796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"AFI","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":46,"lastName":"Barrett","length":250.33098,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"This Celluloid Dream","status":200,"ts":1542310101796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"3 Doors Down","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":24,"lastName":"Kirby","length":243.93098,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"She Don't Want The World","status":200,"ts":1542310217796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":86,"lastName":"Harrell","length":200.22812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Points Of Authority (Album Version)","status":200,"ts":1542310333796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Leatherface and Hot Water Music","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":47,"lastName":"Barrett","length":228.15302,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Gang Party (Leatherface)","status":200,"ts":1542310351796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Agnes","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":25,"lastName":"Kirby","length":186.51383,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Release Me","status":200,"ts":1542310460796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Weezer","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":87,"lastName":"Harrell","length":199.94077,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Island In The Sun","status":200,"ts":1542310533796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Scandinavian Music Group","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":48,"lastName":"Barrett","length":544.88771,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Kun Puut Tekee Seitti\u00c3\u0083\u00c2\u00a4","status":200,"ts":1542310579796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":88,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":605,"song":null,"status":200,"ts":1542310600796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Caparezza","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":26,"lastName":"Kirby","length":310.30812,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Fuori Dal Tunnel (Album Version)","status":200,"ts":1542310646796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Billy Idol","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":89,"lastName":"Harrell","length":228.33587,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Flesh For Fantasy","status":200,"ts":1542310732796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Charttraxx Karaoke","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":27,"lastName":"Kirby","length":225.17506,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Fireflies","status":200,"ts":1542310956796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Michael Bubl\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":90,"lastName":"Harrell","length":229.04118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":605,"song":"Can't Help Falling In Love (Album Version) (Studio)","status":200,"ts":1542310960796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":91,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"Logout","registration":1540472624796.0,"sessionId":605,"song":null,"status":307,"ts":1542310961796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":92,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":605,"song":null,"status":200,"ts":1542310999796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":93,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":605,"song":null,"status":307,"ts":1542311000796,"userAgent":null,"userId":""} {"artist":"Amos Lee","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":49,"lastName":"Barrett","length":178.99057,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":404,"song":"Baby I Want You","status":200,"ts":1542311123796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":null,"auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":50,"lastName":"Barrett","length":null,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540685364796.0,"sessionId":404,"song":null,"status":200,"ts":1542311130796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":94,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":605,"song":null,"status":200,"ts":1542311149796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Notorious B.I.G.","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":28,"lastName":"Kirby","length":252.49914,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Big Poppa","status":200,"ts":1542311181796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Spinanes","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":29,"lastName":"Kirby","length":231.23546,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Azure (Album)","status":200,"ts":1542311433796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Coldplay","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":30,"lastName":"Kirby","length":289.04444,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Brothers & Sisters","status":200,"ts":1542311664796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Evanescence","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":31,"lastName":"Kirby","length":330.91873,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Good Enough","status":200,"ts":1542311953796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"L-Kan","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":32,"lastName":"Kirby","length":246.49098,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Cuentos chinos","status":200,"ts":1542312283796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Peter Mulvey","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":33,"lastName":"Kirby","length":216.24118,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Hidden Love","status":200,"ts":1542312529796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Beverley Craven","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":34,"lastName":"Kirby","length":219.34975,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Promise Me","status":200,"ts":1542312745796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Lonely Island \/ Julian Casablancas","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":35,"lastName":"Kirby","length":192.9922,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Boombox","status":200,"ts":1542312964796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Three Days Grace","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":36,"lastName":"Kirby","length":186.90567,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Just Like You","status":200,"ts":1542313156796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":630,"song":null,"status":307,"ts":1542313251796,"userAgent":null,"userId":""} {"artist":"The Ethiopians","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":37,"lastName":"Kirby","length":142.15791,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Woman Capture Man","status":200,"ts":1542313342796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Fozzy","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":38,"lastName":"Kirby","length":218.14812,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Watch Me Shine (Album)","status":200,"ts":1542313484796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":630,"song":null,"status":200,"ts":1542313682796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Silversun Pickups","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":39,"lastName":"Kirby","length":265.7171,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Booksmart Devil","status":200,"ts":1542313702796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Lionel Richie","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":40,"lastName":"Kirby","length":265.89995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Lady","status":200,"ts":1542313967796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Margaret Cho","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":144.90077,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Gay Porn","status":200,"ts":1542314182796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"A Day To Remember","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":41,"lastName":"Kirby","length":173.13914,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Heart Less","status":200,"ts":1542314232796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Armored Saint","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":325.40689,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Human Vulture","status":200,"ts":1542314326796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Dropkick Murphys","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":42,"lastName":"Kirby","length":232.17587,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"The State Of Massachusetts","status":200,"ts":1542314405796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Fall Out Boy","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":43,"lastName":"Kirby","length":156.57751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Beat It","status":200,"ts":1542314637796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Beck","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":124.15955,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Girl Dreams","status":200,"ts":1542314651796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":209.81506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Intergalactic","status":200,"ts":1542314775796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Fall Out Boy","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":44,"lastName":"Kirby","length":203.96363,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Thnks fr th Mmrs","status":200,"ts":1542314793796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"keller williams","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":230.39955,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"221","status":200,"ts":1542314984796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Al Gromer Khan","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":45,"lastName":"Kirby","length":324.362,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"A Hundred Moons","status":200,"ts":1542314996796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Benny Benassi Presents The Biz","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":205.26975,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Love Is Gonna Save Us ","status":200,"ts":1542315214796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Symphony X","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":46,"lastName":"Kirby","length":318.37995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Evolution (the Grand Design)","status":200,"ts":1542315320796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kajagoogoo","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":365.92281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Big Apple (Metro Mix)","status":200,"ts":1542315419796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jamiroquai","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":47,"lastName":"Kirby","length":229.40689,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Virtual Insanity","status":200,"ts":1542315638796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":220.89098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Somebody To Love","status":200,"ts":1542315784796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bruce Willis","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":48,"lastName":"Kirby","length":228.80608,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Save The Last Dance For Me","status":200,"ts":1542315867796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Killers","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":246.80444,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Read My Mind","status":200,"ts":1542316004796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sharleen Spiteri","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":49,"lastName":"Kirby","length":201.32526,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Cat People (Putting Out Fire)","status":200,"ts":1542316095796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":252.21179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1542316250796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Cardigans","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":50,"lastName":"Kirby","length":198.21669,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Lovefool","status":200,"ts":1542316296796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Black Kids","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":51,"lastName":"Kirby","length":220.05506,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"I'm Not Gonna Teach Your Boyfriend How To Dance With You","status":200,"ts":1542316494796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Parachute","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":146.05016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"She Is Love","status":200,"ts":1542316502796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Mudcrutch","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":249.33832,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"The Wrong Thing To Do (Album Version)","status":200,"ts":1542316648796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Simon Harris","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":52,"lastName":"Kirby","length":195.83955,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Sample Track 2","status":200,"ts":1542316714796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Sufjan Stevens","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":248.89424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Movement III - Linear Tableau with Intersecting Surprise","status":200,"ts":1542316897796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Charlie Patton","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":53,"lastName":"Kirby","length":187.48036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Green River Blues","status":200,"ts":1542316909796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Basshunter","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":54,"lastName":"Kirby","length":223.32036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Walk On Water","status":200,"ts":1542317096796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Lindisfarne","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":352.39138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Fog On The Tyne (Live)","status":200,"ts":1542317145796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kanye West","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":55,"lastName":"Kirby","length":196.77995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Jesus Walks","status":200,"ts":1542317319796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Ariane Moffatt","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":218.53995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Retourne Chez Elle","status":200,"ts":1542317497796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":56,"lastName":"Kirby","length":183.97995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Runaway (Album Version)","status":200,"ts":1542317515796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Beach Boys","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":57,"lastName":"Kirby","length":175.80363,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"You've Got To Hide Your Love Away (Digitally Remastered 01)","status":200,"ts":1542317698796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"No Doubt","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":17,"lastName":"Cuevas","length":261.82485,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Don't Speak","status":200,"ts":1542317715796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Queens Of The Stone Age","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":58,"lastName":"Kirby","length":364.90404,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"God Is On The Radio","status":200,"ts":1542317873796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"LMFAO \/ Lil Jon","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":18,"lastName":"Cuevas","length":222.17098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Shots","status":200,"ts":1542317976796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Suicide Machines","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":19,"lastName":"Cuevas","length":121.41669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"High Anxiety","status":200,"ts":1542318198796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kate Nash","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":59,"lastName":"Kirby","length":255.58159,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Mariella","status":200,"ts":1542318237796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Saturdays","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":20,"lastName":"Cuevas","length":176.95302,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"If This Is Love","status":200,"ts":1542318319796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Frou Frou","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":60,"lastName":"Kirby","length":201.42975,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Holding Out For A Hero","status":200,"ts":1542318492796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Flaw","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":21,"lastName":"Cuevas","length":175.72526,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Get Up Again","status":200,"ts":1542318495796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Liz Callaway","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":22,"lastName":"Cuevas","length":175.43791,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Journey To The Past (LP Version)","status":200,"ts":1542318670796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Les Mis\u00c3\u0083\u00c2\u00a9rables - Original London Cast","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":61,"lastName":"Kirby","length":285.85751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Finale","status":200,"ts":1542318693796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Lady GaGa \/ Colby O'Donis","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":23,"lastName":"Cuevas","length":238.54975,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Just Dance","status":200,"ts":1542318845796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cozy Powell","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":62,"lastName":"Kirby","length":213.4722,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Dance With The Devil","status":200,"ts":1542318978796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Animal Collective","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":24,"lastName":"Cuevas","length":313.5473,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Bluish","status":200,"ts":1542319083796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Blink-182","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":63,"lastName":"Kirby","length":225.12281,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"A New Hope","status":200,"ts":1542319191796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Charisma","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":0,"lastName":"Taylor","length":707.63057,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":482,"song":"Loon Garden","status":200,"ts":1542319258796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"Dido","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":25,"lastName":"Cuevas","length":217.83465,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Thank You","status":200,"ts":1542319396796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Screamin' Jay Hawkins","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":64,"lastName":"Kirby","length":151.58812,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"The Whammy","status":200,"ts":1542319416796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Silverchair","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":65,"lastName":"Kirby","length":241.29261,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"All Across The World","status":200,"ts":1542319567796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Emery","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":26,"lastName":"Cuevas","length":245.4722,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"The Ponytail Parades","status":200,"ts":1542319613796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Hockey","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":66,"lastName":"Kirby","length":196.96281,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Song Away","status":200,"ts":1542319808796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":0,"lastName":"Duffy","length":null,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"GET","page":"Home","registration":1540146037796.0,"sessionId":561,"song":null,"status":200,"ts":1542319830796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Flight Of The Conchords","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":1,"lastName":"Duffy","length":158.14485,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":561,"song":"Hurt Feelings","status":200,"ts":1542319849796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Mike Posner","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":27,"lastName":"Cuevas","length":214.7522,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Cooler Than Me","status":200,"ts":1542319858796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Juana Molina","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":67,"lastName":"Kirby","length":226.61179,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Medlong","status":200,"ts":1542320004796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Nancy Sinatra","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":2,"lastName":"Duffy","length":184.63302,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":561,"song":"So Long_ Babe (2006 Digital Remaster)","status":200,"ts":1542320007796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Joy Division","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":28,"lastName":"Cuevas","length":355.18649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"I Remember Nothing [2007 Re-mastered Album Version]","status":200,"ts":1542320072796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Elvis Presley","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":68,"lastName":"Kirby","length":273.76281,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Suspicious Minds","status":200,"ts":1542320230796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":29,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":630,"song":null,"status":200,"ts":1542320393796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":30,"lastName":"Cuevas","length":201.79546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Revelry","status":200,"ts":1542320427796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kanye West \/ Consequence \/ Cam'Ron","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":69,"lastName":"Kirby","length":333.34812,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Gone","status":200,"ts":1542320503796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Johnny Winter","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":31,"lastName":"Cuevas","length":714.37016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"It's My Own Fault","status":200,"ts":1542320628796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Greg Brown","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":70,"lastName":"Kirby","length":285.28281,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"I Believe I'll Go Back Home","status":200,"ts":1542320836796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Wim Mertens","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":71,"lastName":"Kirby","length":240.79628,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Naviamente","status":200,"ts":1542321121796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Ra Ra Riot","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":32,"lastName":"Cuevas","length":152.71138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Can You Tell","status":200,"ts":1542321342796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":72,"lastName":"Kirby","length":302.91546,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"What If I Do?","status":200,"ts":1542321361796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Vanessa Williams","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":73,"lastName":"Kirby","length":257.14893,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Colors Of The Wind","status":200,"ts":1542321663796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Gyllene Tider","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":74,"lastName":"Kirby","length":253.962,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"(Hon Vill Ha) Puls","status":200,"ts":1542321920796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":33,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Help","registration":1540940782796.0,"sessionId":630,"song":null,"status":200,"ts":1542321973796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ska Cubano","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":34,"lastName":"Cuevas","length":281.44281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Cumbia En Do Menor","status":200,"ts":1542322126796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Train","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":75,"lastName":"Kirby","length":205.45261,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Marry Me","status":200,"ts":1542322173796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Camera Obscura","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":76,"lastName":"Kirby","length":218.69669,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Teenager","status":200,"ts":1542322378796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Liah","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":35,"lastName":"Cuevas","length":195.65669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":630,"song":"Tudo Que Eu Sempre Quis","status":200,"ts":1542322407796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Rise Against","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":77,"lastName":"Kirby","length":245.96853,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Audience Of One","status":200,"ts":1542322596796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Rise Against","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":78,"lastName":"Kirby","length":182.09914,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"My Life Inside Your Heart","status":200,"ts":1542322841796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Sly Fox","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":79,"lastName":"Kirby","length":227.18649,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Let's Go All The Way (Short Blix Mix)","status":200,"ts":1542323023796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Heart","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":80,"lastName":"Kirby","length":296.14975,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Crazy On You","status":200,"ts":1542323250796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Ugly Kid Joe","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":81,"lastName":"Kirby","length":241.03138,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":619,"song":"Cats In The Cradle","status":200,"ts":1542323546796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Traveling Wilburys","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":201.58649,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"You Took My Breath Away (2007 Remastered LP Version)","status":200,"ts":1542324146796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Michael Bubl\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":151.53587,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"A Foggy Day (In London Town) (Album Version)","status":200,"ts":1542324347796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Shakira","gender":"F","itemInSession":0,"lastName":"Hunt","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Home","registration":1540636000796.0,"sessionId":352,"song":null,"status":200,"ts":1542324365796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"84"} {"artist":"S Club 7","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":201.16853,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Have You Ever","status":200,"ts":1542324498796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Hevia","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":3,"lastName":"Kirby","length":256.46975,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Fandangu Los Llobos","status":200,"ts":1542324699796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Billy Talent","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":4,"lastName":"Kirby","length":190.37995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Voices Of Violence (Album Version)","status":200,"ts":1542324955796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Phoenix","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":5,"lastName":"Kirby","length":193.85424,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Courtesy Laughs","status":200,"ts":1542325145796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kanye West","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":6,"lastName":"Kirby","length":242.93832,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"We Don't Care","status":200,"ts":1542325338796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Damero feat. Nevis Peak","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":7,"lastName":"Kirby","length":356.33587,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Gestern_Morgen","status":200,"ts":1542325580796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Shakira","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":8,"lastName":"Kirby","length":289.98485,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Que Me Quedes Tu","status":200,"ts":1542325936796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Big Kuntry King","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":9,"lastName":"Kirby","length":232.75057,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Da Baddest [Feat. Trey Songz] (Explicit Album Version)","status":200,"ts":1542326225796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"}
455.180113
559
0.698309
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Mudhoney","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":10,"lastName":"Kirby","length":231.57506,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Get Into Yours","status":200,"ts":1542326457796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Carpenters","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":11,"lastName":"Kirby","length":238.39302,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Yesterday Once More","status":200,"ts":1542326688796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":12,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":637,"song":null,"status":200,"ts":1542326691796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":13,"lastName":"Kirby","length":185.28608,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Taper Jean Girl","status":200,"ts":1542326926796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Bloody Beetroots","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":14,"lastName":"Kirby","length":201.97832,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Warp 1.9 (feat. Steve Aoki)","status":200,"ts":1542327111796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":15,"lastName":"Kirby","length":201.79546,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Revelry","status":200,"ts":1542327312796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Euge Groove","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":16,"lastName":"Kirby","length":265.482,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Tenderly","status":200,"ts":1542327513796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Soltero","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":17,"lastName":"Kirby","length":249.0771,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Bleeding Hearts","status":200,"ts":1542327778796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Nirvana","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":18,"lastName":"Kirby","length":257.01832,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":637,"song":"Lithium","status":200,"ts":1542328027796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":0,"lastName":"Duffy","length":null,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"GET","page":"Home","registration":1540146037796.0,"sessionId":635,"song":null,"status":200,"ts":1542332019796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":252.21179,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":535,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1542346092796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Lykke Li","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":1,"lastName":"Owens","length":232.35873,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":535,"song":"Melodies & Desires","status":200,"ts":1542346344796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":null,"auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":null,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"GET","page":"Home","registration":1540829025796.0,"sessionId":596,"song":null,"status":200,"ts":1542347789796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":636,"song":null,"status":200,"ts":1542351661796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"Logout","registration":1540940782796.0,"sessionId":636,"song":null,"status":307,"ts":1542351662796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":636,"song":null,"status":200,"ts":1542352827796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":622,"song":null,"status":200,"ts":1542355283796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"The Coffee Club Orchestra","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":386.76853,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":622,"song":"Overture","status":200,"ts":1542355376796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"About","registration":null,"sessionId":636,"song":null,"status":200,"ts":1542355624796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":636,"song":null,"status":307,"ts":1542355625796,"userAgent":null,"userId":""} {"artist":"Harmonia","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":655.77751,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":622,"song":"Sehr kosmisch","status":200,"ts":1542355762796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":614,"song":null,"status":200,"ts":1542355912796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Settings","registration":1540511766796.0,"sessionId":614,"song":null,"status":200,"ts":1542355949796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Alicia Keys","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":182.07302,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":614,"song":"Caged Bird","status":200,"ts":1542355979796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Crosby_ Stills & Nash","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":3,"lastName":"Rodriguez","length":329.19465,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":614,"song":"Wooden Ships (LP Version)","status":200,"ts":1542356161796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"R.E.M.","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":3,"lastName":"Smith","length":241.162,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":622,"song":"What's The Frequency_ Kenneth? (Radio Version)","status":200,"ts":1542356417796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":636,"song":null,"status":200,"ts":1542356874796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eric Clapton","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":323.49995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"My Father's Eyes","status":200,"ts":1542357482796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Godley & Creme","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":237.81832,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"Cry","status":200,"ts":1542357805796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ron Carter","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":497.13587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"I CAN'T GET STARTED","status":200,"ts":1542358042796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Timbaland \/ Keri Hilson \/ D.O.E.","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":179.25179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"The Way I Are","status":200,"ts":1542358469796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Everything But The Girl","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":295.73179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"Missing","status":200,"ts":1542358539796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Big Mountain","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":249.52118,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Baby_ I Love Your Way (Album Version)","status":200,"ts":1542358648796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Gotan Project","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":315.81995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"Queremos Paz","status":200,"ts":1542358834796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Washed Out","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":173.40036,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Belong","status":200,"ts":1542358897796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"OutKast","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":312.13669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"My Favorite Things","status":200,"ts":1542359070796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Black Sabbath","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":388.64934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"Symptom Of The Universe","status":200,"ts":1542359149796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Late Night Alumni","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":226.76853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Uncharted","status":200,"ts":1542359382796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Slightly Stoopid","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":293.82485,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"This Joint","status":200,"ts":1542359537796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":211.722,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Unite (2009 Digital Remaster)","status":200,"ts":1542359608796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Killers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":222.95465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Who Let You Go?","status":200,"ts":1542359819796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Riverside","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":236.2771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"Stuck Between","status":200,"ts":1542359830796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Flobots","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":246.07302,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Good Soldier","status":200,"ts":1542360041796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Lighthouse Family","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":307.53914,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"High","status":200,"ts":1542360066796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":144.06485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Do You Remember","status":200,"ts":1542360287796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Incubus","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":229.22404,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"Pardon Me","status":200,"ts":1542360373796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Edwyn Collins","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":235.91138,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"A Girl Like You","status":200,"ts":1542360431796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Joshua Radin","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":182.62159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"The Fear You Won't Fall","status":200,"ts":1542360602796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bon Iver","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":17,"lastName":"Cuevas","length":116.89751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"Team","status":200,"ts":1542360784796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Bell","length":null,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"GET","page":"Home","registration":1540991795796.0,"sessionId":281,"song":null,"status":200,"ts":1542360812796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 10.0; Windows NT 6.2; WOW64; Trident\/6.0)","userId":"91"} {"artist":"Nipsey Hussle","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":18,"lastName":"Cuevas","length":170.34404,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"Its Hard Out Here","status":200,"ts":1542360900796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":620,"song":null,"status":200,"ts":1542361052796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bebo & Cigala","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":331.15383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Lagrimas Negras","status":200,"ts":1542361289796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":201.79546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Revelry","status":200,"ts":1542361620796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":223.9473,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Love Is A Losing Game","status":200,"ts":1542361821796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":219.66322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1542362044796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Devin Townsend","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":552.98567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Tiny Tears","status":200,"ts":1542362263796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Camera Obscura","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":244.81914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Number One Song","status":200,"ts":1542362815796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":19,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":636,"song":null,"status":200,"ts":1542362932796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Keyshia Cole","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":95.26812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Same Thing","status":200,"ts":1542363059796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Red Hot Chili Peppers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":18,"lastName":"Levine","length":247.66649,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Tell Me Baby (Album Version)","status":200,"ts":1542363154796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":20,"lastName":"Cuevas","length":219.66322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1542363156796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Lit","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":21,"lastName":"Cuevas","length":169.03791,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"My Own Worst Enemy","status":200,"ts":1542363375796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Avenged Sevenfold","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":19,"lastName":"Levine","length":393.50812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Dear God (Album Version)","status":200,"ts":1542363401796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Harmonia","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":22,"lastName":"Cuevas","length":655.77751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"Sehr kosmisch","status":200,"ts":1542363544796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Blue October","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":20,"lastName":"Levine","length":241.162,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Calling You","status":200,"ts":1542363794796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bone Thugs-N-Harmony \/ Akon","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":21,"lastName":"Levine","length":287.52934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"I Tried","status":200,"ts":1542364035796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Training For Utopia","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":23,"lastName":"Cuevas","length":222.37995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"Two Hands","status":200,"ts":1542364199796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Delerium","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":22,"lastName":"Levine","length":455.8624,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Drama","status":200,"ts":1542364322796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Meters","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":24,"lastName":"Cuevas","length":156.21179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"Do The Dirt (Album Version)","status":200,"ts":1542364421796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Harmonia","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":25,"lastName":"Cuevas","length":655.77751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":636,"song":"Sehr kosmisch","status":200,"ts":1542364577796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Macy Gray","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":23,"lastName":"Levine","length":233.89995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Slowly","status":200,"ts":1542364777796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Alice In Chains","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":24,"lastName":"Levine","length":230.60853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"God Smack","status":200,"ts":1542365010796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Dungeon Elite","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":169.82159,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":625,"song":"Give It Up For Me You Us!","status":200,"ts":1542365140796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Angels Of Light & Akron\/Family","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":25,"lastName":"Levine","length":216.60689,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Oceanside","status":200,"ts":1542365240796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Krisiun","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":167.91465,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":625,"song":"In League With Satan","status":200,"ts":1542365309796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Band Of Horses","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":26,"lastName":"Levine","length":275.51302,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Cigarettes_ Wedding Bands (Album)","status":200,"ts":1542365456796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Notorious B.I.G.","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Burns","length":238.78485,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":625,"song":"The What","status":200,"ts":1542365476796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Foolish Things","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":27,"lastName":"Levine","length":266.86649,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Who Can Compare","status":200,"ts":1542365731796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Strokes","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":28,"lastName":"Levine","length":278.64771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"On The Other Side","status":200,"ts":1542365997796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Chick Corea & Hiromi","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":465.05751,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":604,"song":"Windows","status":200,"ts":1542366267796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":29,"lastName":"Levine","length":494.99383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Bleed It Out [Live At Milton Keynes]","status":200,"ts":1542366275796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":26,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":636,"song":null,"status":200,"ts":1542366375796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"DJ Shadow","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":89.28608,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":604,"song":"Transmission 2","status":200,"ts":1542366732796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Fleet Foxes","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":30,"lastName":"Levine","length":147.04281,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"White Winter Hymnal","status":200,"ts":1542366769796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jonas Brothers","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Fox","length":201.27302,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":604,"song":"Games","status":200,"ts":1542366821796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":31,"lastName":"Levine","length":464.92689,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Civil War","status":200,"ts":1542366916796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"!!!","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":32,"lastName":"Levine","length":486.81751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Bend Over Beethoven","status":200,"ts":1542367380796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":27,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Downgrade","registration":1540940782796.0,"sessionId":636,"song":null,"status":200,"ts":1542367750796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Spice Girls","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":33,"lastName":"Levine","length":239.82975,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Who Do You Think You Are","status":200,"ts":1542367866796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Los L\u00c3\u0083\u00c2\u00a1tigos","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":34,"lastName":"Levine","length":263.8624,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Luces Sensacional","status":200,"ts":1542368105796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Willie Colon\/Hector Lavoe","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":35,"lastName":"Levine","length":368.77016,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Triste Y Vacia","status":200,"ts":1542368368796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mike Jones","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":0,"lastName":"White","length":240.90077,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":533,"song":"Mr. Jones (Explicit Version)","status":200,"ts":1542368695796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Place Vendome","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":36,"lastName":"Levine","length":239.04608,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Place Vendome","status":200,"ts":1542368736796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Camera Obscura","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":37,"lastName":"Levine","length":189.3873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Alaska","status":200,"ts":1542368975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Cage The Elephant","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":38,"lastName":"Levine","length":175.12444,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Ain't No Rest For The Wicked (Original Version)","status":200,"ts":1542369164796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":39,"lastName":"Levine","length":271.38567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"The Pretender","status":200,"ts":1542369339796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Notting Hillbillies","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":40,"lastName":"Levine","length":156.47302,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Bewildered","status":200,"ts":1542369610796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Muse","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":41,"lastName":"Levine","length":209.50159,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Supermassive Black Hole (Twilight Soundtrack Version)","status":200,"ts":1542369766796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Owl City","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":42,"lastName":"Levine","length":230.81751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Umbrella Beach","status":200,"ts":1542369975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Ray Barretto","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":43,"lastName":"Levine","length":496.63955,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Canto Abacua","status":200,"ts":1542370205796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Fray","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":44,"lastName":"Levine","length":235.93751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Over My Head (Cable Car)","status":200,"ts":1542370701796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Rokia Traor\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":45,"lastName":"Levine","length":53.86404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Sonorit\u00c3\u0083\u00c2\u00a9s","status":200,"ts":1542370936796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Les Mis\u00c3\u0083\u00c2\u00a9rables - 10th Anniversary Concert","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":46,"lastName":"Levine","length":195.3171,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Castle On A Cloud","status":200,"ts":1542370989796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Usher","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":47,"lastName":"Levine","length":216.24118,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Making Love (Into The Night)","status":200,"ts":1542371184796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"3 Doors Down","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":48,"lastName":"Levine","length":233.74322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Kryptonite","status":200,"ts":1542371400796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Pussycat Dolls","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":49,"lastName":"Levine","length":245.18485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"When I Grow Up","status":200,"ts":1542371633796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Ryan Adams & The Cardinals","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":50,"lastName":"Levine","length":275.22567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Dear John","status":200,"ts":1542371878796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Michael Bubl\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":51,"lastName":"Levine","length":225.90649,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Home (Album Version)","status":200,"ts":1542372153796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Denison Witmer","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":52,"lastName":"Levine","length":223.18975,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Forgiven","status":200,"ts":1542372378796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Matt Pond PA","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":53,"lastName":"Levine","length":245.96853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"If You Want Blood","status":200,"ts":1542372601796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Twista featuring Pharrell Williams","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":54,"lastName":"Levine","length":211.59138,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Give It Up (feat. Pharrell Williams) (Amended Album Version)","status":200,"ts":1542372846796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Frankie Avalon","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":55,"lastName":"Levine","length":186.20036,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"You Are Mine","status":200,"ts":1542373057796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":56,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Downgrade","registration":1540794356796.0,"sessionId":620,"song":null,"status":200,"ts":1542373124796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":0,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":436,"song":null,"status":200,"ts":1542373125796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Frumpies","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":1,"lastName":"Young","length":134.47791,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Fuck Kitty","status":200,"ts":1542373144796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Cyberfit","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":57,"lastName":"Levine","length":303.15057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Pojo Pojo","status":200,"ts":1542373243796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Sheena Easton","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":2,"lastName":"Young","length":185.67791,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"For Your Eyes Only","status":200,"ts":1542373278796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":3,"lastName":"Young","length":173.66159,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Still Take You Home","status":200,"ts":1542373463796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Bob Dylan","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":58,"lastName":"Levine","length":368.92689,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Like A Rolling Stone","status":200,"ts":1542373546796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Justin Timberlake","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":4,"lastName":"Young","length":284.05506,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Let's Take A Ride","status":200,"ts":1542373636796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Shinedown","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":59,"lastName":"Levine","length":228.5971,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":620,"song":"Begin Again (Album Version)","status":200,"ts":1542373914796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":60,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"Logout","registration":1540794356796.0,"sessionId":620,"song":null,"status":307,"ts":1542373915796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":5,"lastName":"Young","length":307.51302,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Clocks","status":200,"ts":1542373920796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Kat DeLuna","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":6,"lastName":"Young","length":239.43791,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Como Un Sue\u00c3\u0083\u00c2\u00b1o (Am I Dreaming)","status":200,"ts":1542374227796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Todd Rundgren","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":7,"lastName":"Young","length":212.29669,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Lord Chancellor's Nightmare Song","status":200,"ts":1542374466796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Eminem \/ Dr. Dre \/ 50 Cent","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":8,"lastName":"Young","length":297.56036,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Crack A Bottle","status":200,"ts":1542374678796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":61,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":620,"song":null,"status":200,"ts":1542374819796,"userAgent":null,"userId":""} {"artist":"La Roux","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":9,"lastName":"Young","length":205.60934,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Bulletproof","status":200,"ts":1542374975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Aerosmith","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":10,"lastName":"Young","length":235.36281,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Pink","status":200,"ts":1542375180796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Colleen","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":11,"lastName":"Young","length":166.5824,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Your Heart On Your Sleeve","status":200,"ts":1542375415796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Nickelback","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":12,"lastName":"Young","length":222.82404,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Should've Listened (Album Version)","status":200,"ts":1542375581796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":13,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Settings","registration":1540465241796.0,"sessionId":436,"song":null,"status":200,"ts":1542375635796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":396.82567,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":465,"song":"Da Funk \/ Dadftendirekt","status":200,"ts":1542375721796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":null,"auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":1,"lastName":"Simpson","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Upgrade","registration":1541044398796.0,"sessionId":465,"song":null,"status":200,"ts":1542375729796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":null,"auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":2,"lastName":"Simpson","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Home","registration":1541044398796.0,"sessionId":465,"song":null,"status":200,"ts":1542375739796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":14,"lastName":"Young","length":195.94404,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Sincerit\u00c3\u0083\u00c2\u00a9 Et Jalousie","status":200,"ts":1542375803796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Beirut","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":15,"lastName":"Young","length":178.72934,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"St. Apollonia","status":200,"ts":1542375998796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Live","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":16,"lastName":"Young","length":183.69261,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"I Walk The Line","status":200,"ts":1542376176796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":null,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1541032432796.0,"sessionId":641,"song":null,"status":200,"ts":1542376329796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Greg Giraldo","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":17,"lastName":"Young","length":243.722,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Monkeypox \/ Osama \/ Bird Flu (Good Day To Cross A River)","status":200,"ts":1542376359796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Hercules And Love Affair","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":18,"lastName":"Young","length":471.74485,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Blind (Frankie Knuckles Remix)","status":200,"ts":1542376602796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":null,"level":"free","location":"New Haven-Milford, CT","method":"GET","page":"Home","registration":1540931983796.0,"sessionId":623,"song":null,"status":200,"ts":1542377063796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Junction 18","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":19,"lastName":"Young","length":189.28281,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Lost In Adeline","status":200,"ts":1542377073796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Plain White T S","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":179.59138,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":623,"song":"Anything","status":200,"ts":1542377162796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"A Day To Remember","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":20,"lastName":"Young","length":269.00853,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"You Had Me At Hello","status":200,"ts":1542377262796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":21,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":436,"song":null,"status":200,"ts":1542377276796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"K. Sparks featuring Dave Barz","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":2,"lastName":"Robinson","length":186.69669,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":623,"song":"My Block","status":200,"ts":1542377341796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Aretha Franklin","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":3,"lastName":"Robinson","length":217.39057,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":623,"song":"You're All I Need To Get By","status":200,"ts":1542377527796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Muse","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":22,"lastName":"Young","length":304.84853,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Uprising","status":200,"ts":1542377531796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Wallflowers","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":4,"lastName":"Robinson","length":312.63302,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":623,"song":"One Headlight","status":200,"ts":1542377744796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":23,"lastName":"Young","length":237.97506,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"All The Right Moves","status":200,"ts":1542377835796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Van Halen","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":24,"lastName":"Young","length":209.29261,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Panama (Remastered Album Version)","status":200,"ts":1542378072796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Rihanna \/ will.i.am","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":25,"lastName":"Young","length":286.32771,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Photographs","status":200,"ts":1542378281796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":26,"lastName":"Young","length":219.66322,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1542378567796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"M83","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":27,"lastName":"Young","length":391.54893,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Carresses","status":200,"ts":1542378786796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Danilo Montero","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":28,"lastName":"Young","length":233.482,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"El es el Rey","status":200,"ts":1542379177796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Who","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":29,"lastName":"Young","length":341.78567,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Eminence Front","status":200,"ts":1542379410796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Ruben Gonzalez","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":30,"lastName":"Young","length":150.41261,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Nuestra Cancion","status":200,"ts":1542379751796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":643,"song":null,"status":200,"ts":1542379801796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"Logout","registration":1540511766796.0,"sessionId":643,"song":null,"status":307,"ts":1542379802796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Psychic Ills","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":512.96608,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":610,"song":"I Knew My Name","status":200,"ts":1542379861796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Lighthouse Family","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":31,"lastName":"Young","length":271.93424,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Lifted","status":200,"ts":1542379901796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":643,"song":null,"status":200,"ts":1542379904796,"userAgent":null,"userId":""} {"artist":"The Ordinary Boys","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":32,"lastName":"Young","length":162.87302,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Boys Will Be Boys","status":200,"ts":1542380172796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Phil Phillips","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":33,"lastName":"Young","length":142.31465,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Sea Of Love","status":200,"ts":1542380334796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Miike Snow","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":34,"lastName":"Young","length":263.88853,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Animal","status":200,"ts":1542380476796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Magdalene","gender":"F","itemInSession":0,"lastName":"Herman","length":null,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"GET","page":"Home","registration":1540766630796.0,"sessionId":244,"song":null,"status":200,"ts":1542380643796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"77"} {"artist":"Booka Shade","auth":"Logged In","firstName":"Magdalene","gender":"F","itemInSession":1,"lastName":"Herman","length":142.10567,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540766630796.0,"sessionId":244,"song":"No Difference","status":200,"ts":1542380653796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"77"} {"artist":"Arma Blanca","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":35,"lastName":"Young","length":359.8624,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"R-Evolucion (con La Odysea y Nach) (La Mision)","status":200,"ts":1542380739796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Santana","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":290.71628,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":644,"song":"Daughter Of The Night","status":200,"ts":1542380758796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Kirk Franklin & The Family","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":0,"lastName":"Summers","length":209.37098,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":532,"song":"Blessing In The Storm","status":200,"ts":1542380850796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Be Bop Deluxe","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":1,"lastName":"Summers","length":314.5922,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":532,"song":"Axe Victim","status":200,"ts":1542381059796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Geri Halliwell","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":36,"lastName":"Young","length":224.91383,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Bag It Up","status":200,"ts":1542381098796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Scissor Sisters","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":37,"lastName":"Young","length":156.94322,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":436,"song":"Intermission","status":200,"ts":1542381322796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":655,"song":null,"status":307,"ts":1542381331796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":657,"song":null,"status":200,"ts":1542381350796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Paramore","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":2,"lastName":"Summers","length":262.71302,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":532,"song":"Brick By Boring Brick [Acoustic Version]","status":200,"ts":1542381373796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":38,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":436,"song":null,"status":200,"ts":1542381375796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":655,"song":null,"status":200,"ts":1542381378796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Rufus Wainwright","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":254.17098,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":657,"song":"Waiting For A Dream","status":200,"ts":1542381378796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Joy Division","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":0,"lastName":"Duffy","length":233.16853,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":640,"song":"Shadowplay","status":200,"ts":1542381379796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Arch Enemy","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":1,"lastName":"Duffy","length":242.70322,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":640,"song":"Symphony Of Destruction","status":200,"ts":1542381612796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":2,"lastName":"Duffy","length":null,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"GET","page":"Home","registration":1540146037796.0,"sessionId":640,"song":null,"status":200,"ts":1542381623796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Johnny Cash with The Carter Family The Statler Brothers & Carl Perkins","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":3,"lastName":"Summers","length":308.34893,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":532,"song":"Closing Medley: Folsom Prison Blues\/I Walk The Line\/Ring Of Fire\/The Rebel - Johnny Yuma","status":200,"ts":1542381635796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Fischer-Z","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":3,"lastName":"Duffy","length":302.78485,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":640,"song":"So Long","status":200,"ts":1542381854796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Vampire Weekend","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":243.04281,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":660,"song":"The Kids Don\u0019t Stand A Chance (Album)","status":200,"ts":1542382318796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":224.67873,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":660,"song":"Secrets","status":200,"ts":1542382561796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Mariah Carey","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":261.82485,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":660,"song":"Bye Bye","status":200,"ts":1542382785796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Thyrfing","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":178.6771,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":647,"song":"Vargavinter","status":200,"ts":1542383107796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Avril Lavigne","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":215.562,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":647,"song":"Alice","status":200,"ts":1542383285796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Nirvana","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Fox","length":186.48771,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":647,"song":"Breed","status":200,"ts":1542383500796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":647,"song":null,"status":200,"ts":1542383504796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Soundgarden","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":290.11546,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":642,"song":"Burden In My Hand","status":200,"ts":1542383631796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Angels and Airwaves","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":4,"lastName":"Fox","length":302.05342,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":647,"song":"The Gift","status":200,"ts":1542383686796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Pedro Aznar","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":185.99138,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":642,"song":"A Primera Vista","status":200,"ts":1542383921796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Something Happens","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":5,"lastName":"Fox","length":175.67302,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":647,"song":"Inviral Love","status":200,"ts":1542383988796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":650,"song":null,"status":200,"ts":1542384300796,"userAgent":null,"userId":""} {"artist":"Kate Ryan","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":209.60608,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":653,"song":"La Promesse (Radio Version)","status":200,"ts":1542384735796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Paramore","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":0,"lastName":"Jones","length":198.21669,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Let The Flames Begin (Album Version)","status":200,"ts":1542385321796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The RH Factor","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":1,"lastName":"Jones","length":143.25506,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Crazy Race","status":200,"ts":1542385519796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Thousand Foot Krutch","auth":"Logged In","firstName":"Andrea","gender":"F","itemInSession":0,"lastName":"Butler","length":58.87955,"level":"free","location":"Pensacola-Ferry Pass-Brent, FL","method":"PUT","page":"NextSong","registration":1541098488796.0,"sessionId":148,"song":"The Invitation","status":200,"ts":1542385641796,"userAgent":"Mozilla\/5.0 (X11; Linux x86_64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"90"} {"artist":"Fey","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":2,"lastName":"Jones","length":267.51955,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Aire","status":200,"ts":1542385662796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Drowning Pool","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":3,"lastName":"Jones","length":201.63873,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Bodies","status":200,"ts":1542385929796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Postal Service","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":4,"lastName":"Jones","length":266.47465,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Such Great Heights","status":200,"ts":1542386130796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":5,"lastName":"Jones","length":211.722,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Unite (2009 Digital Remaster)","status":200,"ts":1542386396796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Jamie Cullum","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":236.79955,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Love Ain't Gonna Let You Down","status":200,"ts":1542386443796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Ours","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":6,"lastName":"Jones","length":240.03873,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Fallen Souls","status":200,"ts":1542386607796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":214.67383,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"One Time","status":200,"ts":1542386679796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":7,"lastName":"Jones","length":196.72771,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Pistol Of Fire","status":200,"ts":1542386847796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Absu","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":57.15546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Twix Yesterday_ the Day & the Morrow","status":200,"ts":1542386893796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bon Iver","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":329.24689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Blindsided","status":200,"ts":1542386950796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":8,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":461,"song":null,"status":200,"ts":1542387272796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"O'Death","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":130.95138,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Gas Can Row","status":200,"ts":1542387279796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Enya","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":227.39546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Wild Child","status":200,"ts":1542387409796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Radiohead","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":9,"lastName":"Jones","length":298.13506,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Let Down","status":200,"ts":1542387499796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Julie London","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":165.58975,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Get Set For The Blues","status":200,"ts":1542387636796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Mindy Smith","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":10,"lastName":"Jones","length":257.17506,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Jolene (Bonus Track)","status":200,"ts":1542387797796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Rogue Wave","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":395.88526,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Harmonium","status":200,"ts":1542387801796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"zebrahead","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":11,"lastName":"Jones","length":229.77261,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Wake Me Up","status":200,"ts":1542388054796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Faudel","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":224.57424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Mon Pays","status":200,"ts":1542388196796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"St. Vincent","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":12,"lastName":"Jones","length":324.10077,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Just The Same But Brand New","status":200,"ts":1542388283796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Frankie Valli","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":201.87383,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Grease (LP Version)","status":200,"ts":1542388420796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Housemartins","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":13,"lastName":"Jones","length":124.05506,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"He Ain't Heavy_ He's My Brother","status":200,"ts":1542388607796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"R\u00c3\u0083\u00c2\u00b6yksopp","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":300.14649,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"What Else Is There?","status":200,"ts":1542388621796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Eagles","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":181.86404,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":667,"song":"Earlybird (LP Version)","status":200,"ts":1542388661796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"David Arkenstone","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":14,"lastName":"Jones","length":363.41506,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Waterfall (Spirit Of The Rainforest Album Version)","status":200,"ts":1542388731796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Metric","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":286.24934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Help I'm Alive","status":200,"ts":1542388921796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"BMX Bandits","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":15,"lastName":"Jones","length":161.27955,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Mailbox","status":200,"ts":1542389094796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":16,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"About","registration":1541062818796.0,"sessionId":461,"song":null,"status":200,"ts":1542389146796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Hot Chip","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":12,"lastName":"Harrell","length":240.37832,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Beach Party","status":200,"ts":1542389207796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Justice","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":13,"lastName":"Harrell","length":285.41342,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Phantom Part 1.5 (Album Version)","status":200,"ts":1542389447796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":17,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"About","registration":1541062818796.0,"sessionId":461,"song":null,"status":200,"ts":1542389541796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Pussycat Dolls","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":14,"lastName":"Harrell","length":197.90322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"I'm Done","status":200,"ts":1542389732796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"N.E.R.D.","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":15,"lastName":"Harrell","length":259.23873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Rock Star","status":200,"ts":1542389929796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Eminem","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":18,"lastName":"Jones","length":261.72036,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Evil Deeds","status":200,"ts":1542390094796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":16,"lastName":"Harrell","length":455.52281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Sympathy For The Devil","status":200,"ts":1542390188796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Leon Jackson","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":19,"lastName":"Jones","length":252.23791,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"When You Believe","status":200,"ts":1542390355796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Drowning Pool","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":20,"lastName":"Jones","length":219.79383,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Hate","status":200,"ts":1542390607796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Michael Bubl\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":17,"lastName":"Harrell","length":194.55955,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Can't Buy Me Love (Album Version)","status":200,"ts":1542390643796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":21,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Help","registration":1541062818796.0,"sessionId":461,"song":null,"status":200,"ts":1542390804796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":22,"lastName":"Jones","length":201.79546,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Revelry","status":200,"ts":1542390826796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Theory Of A Deadman","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":18,"lastName":"Harrell","length":184.89424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Say Goodbye (Album Version)","status":200,"ts":1542390837796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":19,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Downgrade","registration":1540472624796.0,"sessionId":633,"song":null,"status":200,"ts":1542390855796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":23,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Downgrade","registration":1541062818796.0,"sessionId":461,"song":null,"status":200,"ts":1542390856796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":20,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":633,"song":null,"status":200,"ts":1542390925796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Dashboard Confessional","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":21,"lastName":"Harrell","length":147.30404,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"The Good Fight","status":200,"ts":1542391021796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Future Rock","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":24,"lastName":"Jones","length":239.90812,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Gears","status":200,"ts":1542391027796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Cinematic Orchestra feat. Lou Rhodes","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":22,"lastName":"Harrell","length":306.20689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Music Box","status":200,"ts":1542391168796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Police","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":25,"lastName":"Jones","length":300.14649,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Walking On The Moon","status":200,"ts":1542391266796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":23,"lastName":"Harrell","length":214.93506,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Pump It","status":200,"ts":1542391474796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Mars Volta","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":26,"lastName":"Jones","length":1001.74322,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Tetragrammaton","status":200,"ts":1542391566796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":663,"song":null,"status":200,"ts":1542391581796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Crayons","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":462.07955,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":663,"song":"There You Go","status":200,"ts":1542391671796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Dear Nora","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":24,"lastName":"Harrell","length":59.66322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Give Me Some Of Yr Love","status":200,"ts":1542391688796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Lil Scrappy","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":25,"lastName":"Harrell","length":238.78485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Like Me (Amended Version)","status":200,"ts":1542391747796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Escape The Fate","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":26,"lastName":"Harrell","length":266.73587,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"This War Is Ours (The Guillotine II)","status":200,"ts":1542391985796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Travis","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":0,"lastName":"Griffin","length":238.15791,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Side","status":200,"ts":1542392098796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The xx","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":188.55138,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":663,"song":"Basic Space","status":200,"ts":1542392133796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"H\u00c3\u0083\u00c2\u00a9roes del Silencio","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":27,"lastName":"Harrell","length":245.02812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Parasiempre","status":200,"ts":1542392251796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Crosby_ Stills & Nash","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":1,"lastName":"Griffin","length":444.05506,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Suite: Judy Blue Eyes [Remastered LP Version]","status":200,"ts":1542392336796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bad Brains","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":28,"lastName":"Harrell","length":142.78485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"No Conditions","status":200,"ts":1542392496796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"James Taylor","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":27,"lastName":"Jones","length":214.22975,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Secret O' Life","status":200,"ts":1542392567796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Train","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":29,"lastName":"Harrell","length":216.76363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Hey_ Soul Sister","status":200,"ts":1542392638796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":2,"lastName":"Griffin","length":131.3171,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Kiss With A Fist","status":200,"ts":1542392780796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Veggie Tales (Veggie Tunes)","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":28,"lastName":"Jones","length":131.23873,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"King Darius Suite (LP Version)","status":200,"ts":1542392781796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":30,"lastName":"Harrell","length":195.94404,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Sincerit\u00c3\u0083\u00c2\u00a9 Et Jalousie","status":200,"ts":1542392854796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Minnie Riperton","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":3,"lastName":"Griffin","length":164.25751,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Seeing You This Way","status":200,"ts":1542392911796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Weezer","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":29,"lastName":"Jones","length":159.55546,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Buddy Holly","status":200,"ts":1542392912796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Warrior King","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":31,"lastName":"Harrell","length":257.20118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Baby Don't Worry","status":200,"ts":1542393049796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Colbie Caillat","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":30,"lastName":"Jones","length":244.08771,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Realize","status":200,"ts":1542393071796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Passion Pit","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":4,"lastName":"Griffin","length":174.75873,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Sleepyhead","status":200,"ts":1542393075796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":5,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Help","registration":1541057188796.0,"sessionId":407,"song":null,"status":200,"ts":1542393110796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Tilly & The Wall","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":6,"lastName":"Griffin","length":169.58649,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Pot Kettle Black","status":200,"ts":1542393249796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"John Mayer","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":32,"lastName":"Harrell","length":241.6322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Back To You","status":200,"ts":1542393306796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Killers","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":31,"lastName":"Jones","length":344.78975,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Everything Will Be Alright","status":200,"ts":1542393315796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Morning Benders","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":7,"lastName":"Griffin","length":235.20608,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Wet Cement","status":200,"ts":1542393418796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bon Iver","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":33,"lastName":"Harrell","length":186.122,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Creature Fear","status":200,"ts":1542393547796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kelly Clarkson","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":8,"lastName":"Griffin","length":281.5473,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Already Gone","status":200,"ts":1542393653796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Children Of Bodom","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":32,"lastName":"Jones","length":284.96934,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Hate me !","status":200,"ts":1542393659796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":34,"lastName":"Harrell","length":191.76444,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Howlin\u0019 For You","status":200,"ts":1542393733796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Perishers","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":35,"lastName":"Harrell","length":234.16118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":633,"song":"Pills (Live)","status":200,"ts":1542393924796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Train","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":9,"lastName":"Griffin","length":239.93424,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Meet Virginia","status":200,"ts":1542393934796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":10,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"Logout","registration":1541057188796.0,"sessionId":407,"song":null,"status":307,"ts":1542393935796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Barry Manilow","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":33,"lastName":"Jones","length":187.48036,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Can't Smile Without You","status":200,"ts":1542393943796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":11,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":407,"song":null,"status":200,"ts":1542393966796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":12,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":407,"song":null,"status":307,"ts":1542393967796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":13,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":407,"song":null,"status":200,"ts":1542393982796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":14,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Downgrade","registration":1541057188796.0,"sessionId":407,"song":null,"status":200,"ts":1542394035796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Mary MacGregor","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":34,"lastName":"Jones","length":218.20036,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Torn Between Two Lovers","status":200,"ts":1542394130796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Alex Gaudino Feat. Shena","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":15,"lastName":"Griffin","length":174.70649,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Watch Out","status":200,"ts":1542394173796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Passion Pit","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":16,"lastName":"Griffin","length":174.75873,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Sleepyhead","status":200,"ts":1542394347796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Academy Is...","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":35,"lastName":"Jones","length":248.45016,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Every Burden Has A Version (Bonus Track)","status":200,"ts":1542394348796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"No Te Va Gustar","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":17,"lastName":"Griffin","length":263.36608,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Al Vac\u00c3\u0083\u00c2\u00ado","status":200,"ts":1542394521796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Jadakiss","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":36,"lastName":"Jones","length":192.13016,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Kiss Of Death","status":200,"ts":1542394596796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Coldplay","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":18,"lastName":"Griffin","length":268.30322,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Yellow","status":200,"ts":1542394784796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Markus Kruneg\u00c3\u0083\u00c2\u00a5rd","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":37,"lastName":"Jones","length":185.5473,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Genom tunna tyger","status":200,"ts":1542394788796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Expensive Soul","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":38,"lastName":"Jones","length":242.78159,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"\u00c3\u0083\u00c2\u0089 Aqui Que Se Passa Tudo","status":200,"ts":1542394973796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Billy Squier","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":19,"lastName":"Griffin","length":282.04363,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Lonely Is The Night","status":200,"ts":1542395052796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Eminem","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":39,"lastName":"Jones","length":268.5122,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"My Name Is","status":200,"ts":1542395215796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Bright Eyes","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":20,"lastName":"Griffin","length":190.11873,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Drunk Kid Catholic","status":200,"ts":1542395334796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The New Pornographers","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":40,"lastName":"Jones","length":272.71791,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Go Places","status":200,"ts":1542395483796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Craig David","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":21,"lastName":"Griffin","length":255.60771,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Fast Cars","status":200,"ts":1542395524796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Strokes","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":41,"lastName":"Jones","length":278.64771,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"On The Other Side","status":200,"ts":1542395755796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Andrew Bird","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":22,"lastName":"Griffin","length":305.81506,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"How You Gonna Keep 'Em Down On The Farm","status":200,"ts":1542395779796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Against Me!","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":160.67873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Sink_ Florida_ Sink","status":200,"ts":1542396010796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Melendi","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":42,"lastName":"Jones","length":218.22649,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Quiero Ser Feliz","status":200,"ts":1542396033796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Belanova","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":23,"lastName":"Griffin","length":205.50485,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":407,"song":"Escena Final","status":200,"ts":1542396084796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":24,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":407,"song":null,"status":200,"ts":1542396135796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Xavier Rudd","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":252.00281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Let Me Be","status":200,"ts":1542396170796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eric Church","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":43,"lastName":"Jones","length":190.64118,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Guys Like Me","status":200,"ts":1542396251796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":233.69098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Invalid","status":200,"ts":1542396422796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Alison Limerick","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":44,"lastName":"Jones","length":416.02567,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Where Love Lives (Come On In)","status":200,"ts":1542396441796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Godsmack","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":543.52934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Voodoo","status":200,"ts":1542396655796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Erin McKeown","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":45,"lastName":"Jones","length":180.1922,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"La Petite Mort","status":200,"ts":1542396857796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"El-P","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":46,"lastName":"Jones","length":289.33179,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Poisenville Kids No Wins","status":200,"ts":1542397037796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Race Horses","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":120.73751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"No Man's Land","status":200,"ts":1542397198796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Juanes","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":207.20281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Rosario Tijeras","status":200,"ts":1542397318796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Coldplay","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":47,"lastName":"Jones","length":200.93342,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Cemeteries Of London","status":200,"ts":1542397326796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Naast","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":175.85587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Coeur De Glace","status":200,"ts":1542397525796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Nickelback","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":48,"lastName":"Jones","length":238.18404,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Far Away (Album Version)","status":200,"ts":1542397526796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Cartola","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":49,"lastName":"Jones","length":127.242,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Tive Sim","status":200,"ts":1542397764796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Cascada","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":50,"lastName":"Jones","length":302.91546,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Truly_ Madly_ Deeply","status":200,"ts":1542397891796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Rihanna","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":208.40444,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":665,"song":"Te Amo","status":200,"ts":1542398038796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Martin O'Donnell And Michael Salvatori","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":51,"lastName":"Jones","length":185.80853,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Reclaimer","status":200,"ts":1542398193796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":648,"song":null,"status":200,"ts":1542398370796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Lulu","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":52,"lastName":"Jones","length":131.60444,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Where Did You Come From (2002 Digital Remaster)","status":200,"ts":1542398378796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Shinedown","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":53,"lastName":"Jones","length":191.05914,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Cyanide Sweet Tooth Suicide (Album Version)","status":200,"ts":1542398509796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Cage The Elephant","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":54,"lastName":"Jones","length":147.59138,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Drones In The Valley","status":200,"ts":1542398700796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Interpol","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":55,"lastName":"Jones","length":299.72853,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":461,"song":"Rest My Chemistry","status":200,"ts":1542398847796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":56,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"Logout","registration":1541062818796.0,"sessionId":461,"song":null,"status":307,"ts":1542398848796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":57,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":461,"song":null,"status":200,"ts":1542398910796,"userAgent":null,"userId":""} {"artist":"Passenger 10","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":392.75057,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Passenger 10","status":200,"ts":1542399180796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Relient K","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":189.04771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"I Celebrate The Day (Digital Single)","status":200,"ts":1542399572796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Fonseca","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":228.57098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Te Mando Flores","status":200,"ts":1542399761796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Hinder","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":262.05995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Lips Of An Angel","status":200,"ts":1542399989796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Radney Foster","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":0,"lastName":"Summers","length":288.96608,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":661,"song":"Sweet And Wild","status":200,"ts":1542400194796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Tenacious D","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":37.0673,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Destiny","status":200,"ts":1542400251796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"David Banner \/ Lil' Flip","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":258.06322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Like A Pimp","status":200,"ts":1542400288796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Battles","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":1,"lastName":"Summers","length":118.85669,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":661,"song":"Snare Hangar","status":200,"ts":1542400482796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Carla Bruni","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":163.02975,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Quelqu'un M'a Dit (Album Version)","status":200,"ts":1542400546796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Hootie And The Blowfish","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":194.58567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"I Go Blind (LP Version)","status":200,"ts":1542400709796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"La Polla Records","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":69.98159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Lucky Man For You","status":200,"ts":1542400903796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Phish","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":17,"lastName":"Cuevas","length":319.29424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Prince Caspian","status":200,"ts":1542400972796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eminem \/ Nate Dogg","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":18,"lastName":"Cuevas","length":297.9522,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"'Till I Collapse","status":200,"ts":1542401291796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Rise Against","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":19,"lastName":"Cuevas","length":167.65342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"But Tonight We Dance","status":200,"ts":1542401588796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jimmy Eat World","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":20,"lastName":"Cuevas","length":166.00771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"The Middle","status":200,"ts":1542401755796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Josh Rouse","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":21,"lastName":"Cuevas","length":264.25424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Street Lights","status":200,"ts":1542401921796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Prodigy","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":22,"lastName":"Cuevas","length":308.4273,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Spitfire (Album Version)","status":200,"ts":1542402185796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":593,"song":null,"status":200,"ts":1542402348796,"userAgent":null,"userId":""} {"artist":"Timbaland \/ Keri Hilson \/ D.O.E.","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":23,"lastName":"Cuevas","length":179.25179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"The Way I Are","status":200,"ts":1542402493796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Yann Tiersen","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":24,"lastName":"Cuevas","length":55.69261,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"IV","status":200,"ts":1542402672796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Carolina Chocolate Drops","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":25,"lastName":"Cuevas","length":147.46077,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Cindy Gal (Album Version)","status":200,"ts":1542402727796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Mpiri","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":26,"lastName":"Cuevas","length":269.92281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"EG GLE\u00c3\u0083\u00c2\u0090IST SO HV\u00c3\u0083\u00c2\u0098RT J\u00c3\u0083\u00c2\u0093LAKV\u00c3\u0083\u00c2\u0098LD","status":200,"ts":1542402874796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Hollywood Undead","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":27,"lastName":"Cuevas","length":174.2624,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Dove And Grenade","status":200,"ts":1542403143796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eminem","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":28,"lastName":"Cuevas","length":248.58077,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Just Lose It","status":200,"ts":1542403317796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Pearl Jam","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":29,"lastName":"Cuevas","length":179.33016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Let Me Sleep (It's Christmas Time)","status":200,"ts":1542403565796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":30,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Settings","registration":1540940782796.0,"sessionId":648,"song":null,"status":200,"ts":1542405423796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":31,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Settings","registration":1540940782796.0,"sessionId":648,"song":null,"status":200,"ts":1542406669796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":32,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"Save Settings","registration":1540940782796.0,"sessionId":648,"song":null,"status":307,"ts":1542406670796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":33,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":648,"song":null,"status":200,"ts":1542406798796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Limp Bizkit","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":34,"lastName":"Cuevas","length":214.5171,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Rollin' (Air Raid Vehicle)","status":200,"ts":1542408415796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Calogero","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":35,"lastName":"Cuevas","length":264.202,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Aussi Libre Que Moi","status":200,"ts":1542408629796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"HELLYEAH","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":36,"lastName":"Cuevas","length":58.95791,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"In the Mood","status":200,"ts":1542408893796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"K'Naan","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":37,"lastName":"Cuevas","length":220.49914,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Wavin' Flag","status":200,"ts":1542408951796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cameo","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":211.98322,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":577,"song":"Word Up!","status":200,"ts":1542409085796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":38,"lastName":"Cuevas","length":172.22485,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"The Maestro","status":200,"ts":1542409171796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Trentem\u00c3\u0083\u00c2\u00b8ller","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":39,"lastName":"Cuevas","length":247.562,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Miss You","status":200,"ts":1542409343796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eagle Seagull","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":40,"lastName":"Cuevas","length":242.6771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"You Can't Call Yourself A Secret","status":200,"ts":1542409590796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Luke Bryan","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":41,"lastName":"Cuevas","length":175.17669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Rain Is A Good Thing","status":200,"ts":1542409832796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Steve Ouimette","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":42,"lastName":"Cuevas","length":375.06567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"The Devil Went Down To Georgia","status":200,"ts":1542410007796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jill Scott","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":43,"lastName":"Cuevas","length":231.52281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Golden","status":200,"ts":1542410382796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Edward Sharpe & The Magnetic Zeros","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":44,"lastName":"Cuevas","length":306.31138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Home","status":200,"ts":1542410613796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Muse","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":45,"lastName":"Cuevas","length":346.69669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Resistance","status":200,"ts":1542410919796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Usher featuring will.i.am","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":46,"lastName":"Cuevas","length":395.72853,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"OMG","status":200,"ts":1542411265796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Nine Inch Nails","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":47,"lastName":"Cuevas","length":254.71955,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Gave Up","status":200,"ts":1542411660796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Franz Ferdinand","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":48,"lastName":"Cuevas","length":254.79791,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"This Fire","status":200,"ts":1542411914796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":674,"song":null,"status":200,"ts":1542412126796,"userAgent":null,"userId":""} {"artist":"America","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":49,"lastName":"Cuevas","length":223.97342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Tin Man (Live)","status":200,"ts":1542412168796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":50,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":648,"song":null,"status":200,"ts":1542412219796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Built To Spill","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":51,"lastName":"Cuevas","length":357.642,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Some (Album)","status":200,"ts":1542412391796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":52,"lastName":"Cuevas","length":196.91057,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Broken","status":200,"ts":1542412748796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"}
458.403141
608
0.697768
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Kenny G","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":53,"lastName":"Cuevas","length":256.57424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Everlasting","status":200,"ts":1542412944796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Randy Crawford","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":54,"lastName":"Cuevas","length":251.402,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Rio De Janeiro Blue (Album Version)","status":200,"ts":1542413200796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Placebo","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":55,"lastName":"Cuevas","length":224.02567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Breathe Underwater","status":200,"ts":1542413451796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Poison The Well","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":56,"lastName":"Cuevas","length":184.60689,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Riverside","status":200,"ts":1542413675796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":57,"lastName":"Cuevas","length":196.88444,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"U Smile","status":200,"ts":1542413859796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Type O Negative","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":58,"lastName":"Cuevas","length":366.23628,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Can't Lose You (Album Version)","status":200,"ts":1542414055796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":59,"lastName":"Cuevas","length":260.15302,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Happy Endings","status":200,"ts":1542414421796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eminem","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":252.73424,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":659,"song":"Still Don't Give A Fuck","status":200,"ts":1542414487796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Silversun Pickups","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":60,"lastName":"Cuevas","length":353.61914,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Growing Old Is Getting Old (Album Version)","status":200,"ts":1542414681796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kid Rock","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":61,"lastName":"Cuevas","length":396.72118,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"New Orleans (Album Version)","status":200,"ts":1542415034796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Clifford Brown","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":62,"lastName":"Cuevas","length":662.83057,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Night In Tunisia","status":200,"ts":1542415430796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"New Found Glory","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":63,"lastName":"Cuevas","length":222.45832,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"My Friends Over You","status":200,"ts":1542416092796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Elton John","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":64,"lastName":"Cuevas","length":417.01832,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Song For Guy","status":200,"ts":1542416314796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Hot Chip","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":65,"lastName":"Cuevas","length":198.76526,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Tchaparian","status":200,"ts":1542416731796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ratatat","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":66,"lastName":"Cuevas","length":226.53342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Loud Pipes","status":200,"ts":1542416929796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Tech N9ne","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":67,"lastName":"Cuevas","length":345.5473,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Going Bad","status":200,"ts":1542417155796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Judy Cheeks","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":68,"lastName":"Cuevas","length":333.08689,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"So In Love (The Real Deal) (Frankie Foncett Vocal Mix)","status":200,"ts":1542417500796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Offspring","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":69,"lastName":"Cuevas","length":167.65342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Cool To Hate (Album version)","status":200,"ts":1542417833796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":70,"lastName":"Cuevas","length":177.84118,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Fake Tales Of San Francisco (Explicit)","status":200,"ts":1542418000796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Pinback","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":71,"lastName":"Cuevas","length":286.56281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Penelope","status":200,"ts":1542418177796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Edwyn Collins","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":72,"lastName":"Cuevas","length":235.91138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"A Girl Like You","status":200,"ts":1542418463796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Air","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":73,"lastName":"Cuevas","length":244.50567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Venus","status":200,"ts":1542418698796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Los Lobos","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":74,"lastName":"Cuevas","length":247.74485,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":648,"song":"Good Morning Aztlan","status":200,"ts":1542418942796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Samael","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":247.09179,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":677,"song":"God's Snake","status":200,"ts":1542421252796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Infected Mushroom","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":0,"lastName":"Cook","length":423.6273,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":616,"song":"Saeed","status":200,"ts":1542429098796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Shaft","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":1,"lastName":"Cook","length":207.46404,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":616,"song":"(Mucho Mambo) Sway","status":200,"ts":1542429521796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":2,"lastName":"Cook","length":307.51302,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":616,"song":"Clocks","status":200,"ts":1542429728796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"The Kills","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":3,"lastName":"Cook","length":287.97342,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":616,"song":"Wait","status":200,"ts":1542430035796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Cut Copy","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":4,"lastName":"Cook","length":61.962,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":616,"song":"We Fight For Diamonds","status":200,"ts":1542430322796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Telepath","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":5,"lastName":"Cook","length":304.19546,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":616,"song":"Globalized","status":200,"ts":1542430383796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Daddy Yankee","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":6,"lastName":"Cook","length":214.77832,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":616,"song":"Somos De Calle","status":200,"ts":1542430687796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Ennio Morricone","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":7,"lastName":"Cook","length":215.01342,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":616,"song":"Chi Mai (El Profesional)","status":200,"ts":1542430901796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Moby","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":0,"lastName":"Harris","length":240.74404,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":516,"song":"In This World","status":200,"ts":1542430957796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Plain White T's","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":8,"lastName":"Cook","length":232.202,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":616,"song":"Hey There Delilah","status":200,"ts":1542431116796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"The Hush Sound","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":192.46975,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":581,"song":"A Dark Congregation (Album Version)","status":200,"ts":1542436308796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":1,"lastName":"Hicks","length":212.32281,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":581,"song":"Goodbye_ Apathy","status":200,"ts":1542436500796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":null,"auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":0,"lastName":"Benjamin","length":null,"level":"free","location":"Plymouth, IN","method":"GET","page":"Home","registration":1539908999796.0,"sessionId":354,"song":null,"status":200,"ts":1542449795796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":1,"lastName":"Benjamin","length":183.97995,"level":"free","location":"Plymouth, IN","method":"PUT","page":"NextSong","registration":1539908999796.0,"sessionId":354,"song":"Runaway (Album Version)","status":200,"ts":1542450082796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":"Inverse","auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":2,"lastName":"Benjamin","length":225.69751,"level":"free","location":"Plymouth, IN","method":"PUT","page":"NextSong","registration":1539908999796.0,"sessionId":354,"song":"Spark My Soul (feat. Substantial)","status":200,"ts":1542450265796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":"The Ramones","auth":"Logged In","firstName":"Jizelle","gender":"F","itemInSession":3,"lastName":"Benjamin","length":210.18077,"level":"free","location":"Plymouth, IN","method":"PUT","page":"NextSong","registration":1539908999796.0,"sessionId":354,"song":"Pet Semetary","status":200,"ts":1542450490796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"2"} {"artist":"iio","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":270.36689,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":670,"song":"Smooth","status":200,"ts":1542459151796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":null,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"GET","page":"Home","registration":1540829025796.0,"sessionId":664,"song":null,"status":200,"ts":1542461639796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Britt Nicole","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":0,"lastName":"Klein","length":247.48363,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Say It","status":200,"ts":1542461890796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"K's Choice","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":1,"lastName":"Klein","length":206.78485,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Another Year","status":200,"ts":1542462137796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Sound 5","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":2,"lastName":"Klein","length":451.21261,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Latin Static","status":200,"ts":1542462343796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"10cc","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":3,"lastName":"Klein","length":300.40771,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Hotel","status":200,"ts":1542462794796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Underworld","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":4,"lastName":"Klein","length":700.81261,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Born Slippy","status":200,"ts":1542463094796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Plastilina Mosh","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":5,"lastName":"Klein","length":222.95465,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Ni\u00c3\u0083\u00c2\u00b1o Bomba","status":200,"ts":1542463794796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Billy Idol","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":6,"lastName":"Klein","length":254.01424,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Yellin' At The Xmas Tree","status":200,"ts":1542464016796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Coko featuring Kirk Franklin","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":7,"lastName":"Klein","length":249.3122,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"I Get Joy","status":200,"ts":1542464270796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Tech N9ne","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":8,"lastName":"Klein","length":301.76608,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Thugged-Out","status":200,"ts":1542464519796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Kudai","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":9,"lastName":"Klein","length":225.82812,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Ya Nada Queda","status":200,"ts":1542464820796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Slightly Stoopid","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":10,"lastName":"Klein","length":158.71955,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Till It Gets Wet","status":200,"ts":1542465045796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Killers","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":11,"lastName":"Klein","length":254.85016,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Daddy's Eyes","status":200,"ts":1542465203796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Final Fantasy","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":12,"lastName":"Klein","length":152.97261,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"None Of You Will Ever See A Penny","status":200,"ts":1542465457796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Snow Patrol","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":13,"lastName":"Klein","length":200.93342,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Crack The Shutters","status":200,"ts":1542465609796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":14,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"Logout","registration":1540558108796.0,"sessionId":518,"song":null,"status":307,"ts":1542465610796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":15,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":518,"song":null,"status":200,"ts":1542465783796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":16,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":518,"song":null,"status":307,"ts":1542465784796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":17,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Home","registration":1540558108796.0,"sessionId":518,"song":null,"status":200,"ts":1542465815796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Jorge Drexler","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":18,"lastName":"Klein","length":224.57424,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Ganas De Ti (Album Version)","status":200,"ts":1542465905796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Emmy The Great","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":19,"lastName":"Klein","length":204.79955,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Mia","status":200,"ts":1542466129796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Big Tymers \/ Gotti \/ TQ \/ Mikkey","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":20,"lastName":"Klein","length":222.40608,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Sunny Day","status":200,"ts":1542466333796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Molotov","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":21,"lastName":"Klein","length":210.07628,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Frijolero","status":200,"ts":1542466555796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":233.69098,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":646,"song":"Invalid","status":200,"ts":1542466611796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Gin Blossoms","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":233.482,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":679,"song":"Day Job","status":200,"ts":1542466761796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Che Sudaka","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":22,"lastName":"Klein","length":160.49587,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Bihotza","status":200,"ts":1542466765796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Audioslave","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":273.65832,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":646,"song":"Yesterday To Tomorrow","status":200,"ts":1542466844796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Erin Bode","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":23,"lastName":"Klein","length":252.05506,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Here_ There And Everywhere","status":200,"ts":1542466925796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Calle 13","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":239.3073,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":679,"song":"Atr\u00c3\u0083\u00c2\u00a9vete te te","status":200,"ts":1542466994796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Selena Gomez & The Scene","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Burns","length":184.65914,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":646,"song":"Falling Down","status":200,"ts":1542467117796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":24,"lastName":"Klein","length":277.15873,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1542467177796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Colbie Caillat","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":25,"lastName":"Klein","length":233.16853,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"I Never Told You","status":200,"ts":1542467454796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Black Crowes","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":26,"lastName":"Klein","length":223.65995,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Mellow Down Easy","status":200,"ts":1542467687796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Aloe Blacc","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":27,"lastName":"Klein","length":244.1922,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"I Need A Dollar","status":200,"ts":1542467910796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Datarock","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":28,"lastName":"Klein","length":169.50812,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"True Stories","status":200,"ts":1542468154796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Benjy Ferree","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":29,"lastName":"Klein","length":169.89995,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Fear","status":200,"ts":1542468323796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Lighter Shade of Brown","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":30,"lastName":"Klein","length":211.85261,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Homies","status":200,"ts":1542468492796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Kinky","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":31,"lastName":"Klein","length":190.92853,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Soun Tha Mi Primer Amor","status":200,"ts":1542468703796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Pepper","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":32,"lastName":"Klein","length":139.98975,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Blackout","status":200,"ts":1542468893796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Lionel Richie","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":33,"lastName":"Klein","length":249.62567,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Hello","status":200,"ts":1542469032796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Fat Freddys Drop","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":34,"lastName":"Klein","length":431.28118,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"The Raft","status":200,"ts":1542469281796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Aqua","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":35,"lastName":"Klein","length":201.92608,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Doctor Jones","status":200,"ts":1542469712796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":36,"lastName":"Klein","length":193.43628,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"From The Ritz To The Rubble","status":200,"ts":1542469913796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":629,"song":null,"status":200,"ts":1542470025796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":629,"song":null,"status":307,"ts":1542470026796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":2,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1540871783796.0,"sessionId":629,"song":null,"status":200,"ts":1542470039796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Crests","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":3,"lastName":"Watkins","length":182.88281,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":629,"song":"16 Candles","status":200,"ts":1542470050796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Onra","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":37,"lastName":"Klein","length":120.94649,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"TAKE A RIDE","status":200,"ts":1542470106796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Jets To Brazil","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":38,"lastName":"Klein","length":305.73669,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Cat Heaven","status":200,"ts":1542470226796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Extreme","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":4,"lastName":"Watkins","length":238.99383,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":629,"song":"More Than Words","status":200,"ts":1542470232796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"John Mayer","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":5,"lastName":"Watkins","length":269.71383,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":629,"song":"Heartbreak Warfare","status":200,"ts":1542470470796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Knife","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":39,"lastName":"Klein","length":292.54485,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Silent Shout","status":200,"ts":1542470531796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540492941796.0,"sessionId":654,"song":null,"status":200,"ts":1542470641796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Nelson Ned","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":6,"lastName":"Watkins","length":187.24526,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":629,"song":"Eu Gosto Tanto De Voce","status":200,"ts":1542470739796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Mars Volta","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":40,"lastName":"Klein","length":472.39791,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"With Twilight as My Guide","status":200,"ts":1542470823796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Cyan Velvet Project","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":7,"lastName":"Watkins","length":205.16526,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":629,"song":"Dead Skin (edit)","status":200,"ts":1542470926796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":8,"lastName":"Watkins","length":233.69098,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":629,"song":"Invalid","status":200,"ts":1542471131796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Thee Silver Mountain Reveries","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":41,"lastName":"Klein","length":587.38893,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Microphones in the Trees","status":200,"ts":1542471295796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Red Hot Chili Peppers","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":9,"lastName":"Watkins","length":334.65424,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":629,"song":"Snow [Hey Oh] (Album Version)","status":200,"ts":1542471364796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":10,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"About","registration":1540871783796.0,"sessionId":629,"song":null,"status":200,"ts":1542471368796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":11,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"About","registration":1540871783796.0,"sessionId":629,"song":null,"status":200,"ts":1542471369796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Metallica","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":42,"lastName":"Klein","length":515.21261,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Master Of Puppets","status":200,"ts":1542471882796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Bikini Kill","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":43,"lastName":"Klein","length":149.81179,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Reject All American","status":200,"ts":1542472397796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":44,"lastName":"Klein","length":204.59057,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Every Lasting Light","status":200,"ts":1542472546796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Jake Hess","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":45,"lastName":"Klein","length":199.26159,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"You And Me Jesus","status":200,"ts":1542472750796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"B.o.B","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":46,"lastName":"Klein","length":269.63546,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Nothin' On You [feat. Bruno Mars] (Album Version)","status":200,"ts":1542472949796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Collective Soul","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":47,"lastName":"Klein","length":155.29751,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Reunion (LP Version)","status":200,"ts":1542473218796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Three Drives","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":48,"lastName":"Klein","length":411.6371,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Greece 2000","status":200,"ts":1542473373796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Vanity Fare","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":49,"lastName":"Klein","length":152.86812,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Early In The Morning","status":200,"ts":1542473784796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Drake \/ Kanye West \/ Lil Wayne \/ Eminem","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":50,"lastName":"Klein","length":357.66812,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":518,"song":"Forever","status":200,"ts":1542473936796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":0,"lastName":"White","length":null,"level":"free","location":"Lubbock, TX","method":"GET","page":"Home","registration":1540708070796.0,"sessionId":649,"song":null,"status":200,"ts":1542475846796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Aleks Syntek","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":1,"lastName":"White","length":300.14649,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":649,"song":"Tu Necesitas (2008 Digital Remaster)","status":200,"ts":1542475896796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"The Grapes Of Wrath","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":2,"lastName":"White","length":138.05669,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":649,"song":"All The Things I Wasn't","status":200,"ts":1542476196796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Rilo Kiley","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":3,"lastName":"White","length":215.64036,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":649,"song":"Silver Lining (Album Version)","status":200,"ts":1542476334796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Lonnie Gordon","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":4,"lastName":"White","length":181.21098,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":649,"song":"Catch You Baby (Steve Pitron & Max Sanna Radio Edit)","status":200,"ts":1542476549796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Matt Costa","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":246.02077,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":669,"song":"Unfamiliar Faces","status":200,"ts":1542490357796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":null,"auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":null,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"Logout","registration":1540931983796.0,"sessionId":669,"song":null,"status":307,"ts":1542490358796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":669,"song":null,"status":200,"ts":1542490463796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":669,"song":null,"status":307,"ts":1542490464796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":4,"lastName":"Robinson","length":null,"level":"free","location":"New Haven-Milford, CT","method":"GET","page":"Home","registration":1540931983796.0,"sessionId":669,"song":null,"status":200,"ts":1542490495796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Capital Inicial","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":0,"lastName":"Hayes","length":228.67546,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"F\u00c3\u0083\u00c2\u00a1tima","status":200,"ts":1542494696796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":null,"auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":1,"lastName":"Hayes","length":null,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"GET","page":"Help","registration":1541003367796.0,"sessionId":113,"song":null,"status":200,"ts":1542494701796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"A Day To Remember","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":2,"lastName":"Hayes","length":243.22567,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"If It Means A Lot To You","status":200,"ts":1542494924796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":3,"lastName":"Hayes","length":236.93016,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"Bubble Toes","status":200,"ts":1542495167796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":4,"lastName":"Hayes","length":246.17751,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"DARE","status":200,"ts":1542495403796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":5,"lastName":"Hayes","length":220.18567,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"You And I Both (LP Version)","status":200,"ts":1542495649796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Ligabue","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":6,"lastName":"Hayes","length":246.20363,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"I duri hanno due cuori","status":200,"ts":1542495869796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Steve Miller Band","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":7,"lastName":"Hayes","length":306.23302,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"Abracadabra","status":200,"ts":1542496115796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"38 Special","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":8,"lastName":"Hayes","length":280.76363,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"Caught Up In You","status":200,"ts":1542496421796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Wonderwall","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":9,"lastName":"Hayes","length":281.02485,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"Just More (Album Version)","status":200,"ts":1542496701796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Pepper","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":10,"lastName":"Hayes","length":166.32118,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"Slave","status":200,"ts":1542496982796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Buckcherry","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":11,"lastName":"Hayes","length":208.66567,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"Next 2 You (Album Version)","status":200,"ts":1542497148796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Travie McCoy","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":12,"lastName":"Hayes","length":211.12118,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"Billionaire [feat. Bruno Mars] (Explicit Album Version)","status":200,"ts":1542497356796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":13,"lastName":"Hayes","length":224.67873,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"Secrets","status":200,"ts":1542497567796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Hawk Nelson","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":174.81098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":680,"song":"California","status":200,"ts":1542497651796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Pearl Jam","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":14,"lastName":"Hayes","length":258.48118,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"Faithful","status":200,"ts":1542497791796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"JOSEF LOCKE & ORCHESTRA","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":166.26893,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":680,"song":"How Can You Buy Killarney (1992 Digital Remaster)","status":200,"ts":1542497825796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Project 86","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":777.58649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":680,"song":"Twenty Three (LP Version)","status":200,"ts":1542497991796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":15,"lastName":"Hayes","length":536.13669,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"Revolution 909 (Roger Sanchez Remix)","status":200,"ts":1542498049796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":680,"song":null,"status":200,"ts":1542498375796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"38 Special","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":16,"lastName":"Hayes","length":280.76363,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"Caught Up In You","status":200,"ts":1542498585796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":186.51383,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":680,"song":"Proud Mary","status":200,"ts":1542498768796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ill Nino","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":17,"lastName":"Hayes","length":175.22893,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"My Resurrection (Album Version)","status":200,"ts":1542498865796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"The Police","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":289.85424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":680,"song":"So Lonely","status":200,"ts":1542498954796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bitter:Sweet","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":18,"lastName":"Hayes","length":160.78322,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":113,"song":"Take 2 Blue","status":200,"ts":1542499040796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"}
452.184932
601
0.696481
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Rokia Traor\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":0,"lastName":"White","length":274.88608,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":693,"song":"Zen","status":200,"ts":1542508401796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":null,"auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":0,"lastName":"Garrison","length":null,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"GET","page":"Home","registration":1540832693796.0,"sessionId":555,"song":null,"status":200,"ts":1542511280796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":"Camila","auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":1,"lastName":"Garrison","length":230.81751,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"PUT","page":"NextSong","registration":1540832693796.0,"sessionId":555,"song":"Abrazame (Version Acustica)","status":200,"ts":1542511324796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":null,"auth":"Logged In","firstName":"Ann","gender":"F","itemInSession":0,"lastName":"Banks","length":null,"level":"free","location":"Salt Lake City, UT","method":"GET","page":"Home","registration":1540895683796.0,"sessionId":573,"song":null,"status":200,"ts":1542532333796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"99"} {"artist":"Carl Thomas","auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":0,"lastName":"Garrison","length":196.67546,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"PUT","page":"NextSong","registration":1540832693796.0,"sessionId":698,"song":"You Ain't Right (Album Version)","status":200,"ts":1542533944796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":"N.E.R.D.","auth":"Logged In","firstName":"James","gender":"M","itemInSession":0,"lastName":"Martin","length":242.99057,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540810448796.0,"sessionId":78,"song":"Provider (Remix Radio Edit)","status":200,"ts":1542536291796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 9.0; Windows NT 6.1; Trident\/5.0)","userId":"79"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":589,"song":null,"status":200,"ts":1542546633796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":589,"song":null,"status":307,"ts":1542546634796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":2,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":589,"song":null,"status":200,"ts":1542546896796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Lil Jon \/ The East Side Boyz \/ DJ Flexx","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":3,"lastName":"Lynch","length":285.30893,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Aww Skeet Skeet","status":200,"ts":1542546961796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Enya","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":4,"lastName":"Lynch","length":175.85587,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"The Sun In The Stream","status":200,"ts":1542547246796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Furthermore","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":5,"lastName":"Lynch","length":278.41261,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"We Need To Talk (She And I Album Version)","status":200,"ts":1542547421796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kid Cudi \/ MGMT \/ Ratatat","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":6,"lastName":"Lynch","length":295.67955,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Pursuit Of Happiness (nightmare)","status":200,"ts":1542547699796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Crosby_ Stills & Nash","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":7,"lastName":"Lynch","length":186.90567,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Haven't We Lost Enough? (LP Version)","status":200,"ts":1542547994796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Passion Pit","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":8,"lastName":"Lynch","length":174.75873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Sleepyhead","status":200,"ts":1542548180796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Keith Sweat","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":9,"lastName":"Lynch","length":295.78404,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Merry Go Round (Remastered Single Version)","status":200,"ts":1542548354796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":0,"lastName":"Taylor","length":null,"level":"free","location":"St. Louis, MO-IL","method":"GET","page":"Home","registration":1540992766796.0,"sessionId":634,"song":null,"status":200,"ts":1542548632796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"Mariza","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":1,"lastName":"Taylor","length":166.5824,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":634,"song":"Rosa Branca","status":200,"ts":1542548635796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"In Flames","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":10,"lastName":"Lynch","length":202.84036,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Like you better dead","status":200,"ts":1542548649796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Cute Is What We Aim For","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":2,"lastName":"Taylor","length":211.33016,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":634,"song":"Newport Living (Album Version)","status":200,"ts":1542548801796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":11,"lastName":"Lynch","length":245.02812,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Too Far Gone","status":200,"ts":1542548851796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Cam'Ron \/ Juelz Santana \/ Un Kasa","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":3,"lastName":"Taylor","length":228.38812,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":634,"song":"Take Em To Church","status":200,"ts":1542549012796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"Sick Puppies","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":12,"lastName":"Lynch","length":227.83955,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Don't Walk Away","status":200,"ts":1542549096796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Rapsusklei","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":13,"lastName":"Lynch","length":263.96689,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Nube Inerte (con Aniki)","status":200,"ts":1542549323796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Jonezetta","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":14,"lastName":"Lynch","length":35.63057,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Untitled","status":200,"ts":1542549586796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Cut Copy","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":15,"lastName":"Lynch","length":237.50485,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"A Dream","status":200,"ts":1542549621796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":16,"lastName":"Lynch","length":261.74649,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Halo","status":200,"ts":1542549858796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Easy Star All-Stars","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":17,"lastName":"Lynch","length":198.94812,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Getting Better (feat. The Mighty Diamonds)","status":200,"ts":1542550119796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Blue Man Group","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":18,"lastName":"Lynch","length":205.76608,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Sing Along [Featuring Dave Matthews]","status":200,"ts":1542550317796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Carpark North","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":19,"lastName":"Lynch","length":279.2224,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Run","status":200,"ts":1542550522796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Fleetwoods","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":20,"lastName":"Lynch","length":146.05016,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Come Softly To Me","status":200,"ts":1542550801796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Radiohead","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":21,"lastName":"Lynch","length":298.13506,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Let Down","status":200,"ts":1542550947796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":22,"lastName":"Lynch","length":268.45995,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Demon Days","status":200,"ts":1542551245796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Reginald Dixon","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":23,"lastName":"Lynch","length":188.55138,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Eton Boating Song\/Wyoming Lullaby\/The Wiffenpoof Song (Baa Baa Baa) (Medley)","status":200,"ts":1542551513796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":24,"lastName":"Lynch","length":152.13669,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Pirate Jet","status":200,"ts":1542551701796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"OceanLab","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":25,"lastName":"Lynch","length":440.842,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Clear Blue Water","status":200,"ts":1542551853796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Macy Gray","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":26,"lastName":"Lynch","length":236.09424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Oh Yeah","status":200,"ts":1542552293796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"David Bowie","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":174.41914,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":690,"song":"Sorrow (1997 Digital Remaster)","status":200,"ts":1542552369796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Tavares","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":27,"lastName":"Lynch","length":374.09914,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Don't Take Away The Music","status":200,"ts":1542552529796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The String Cheese Incident","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":1,"lastName":"Gonzalez","length":392.35873,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":690,"song":"Bigger Isn't Better","status":200,"ts":1542552543796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Pixies","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Roth","length":113.78893,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":511,"song":"Break My Body","status":200,"ts":1542552806796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":"Meet Me In St Louis","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":28,"lastName":"Lynch","length":275.27791,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"I've Got Knives In My Eyes I'm Going Home Sick","status":200,"ts":1542552903796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Syd Barrett","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":29,"lastName":"Lynch","length":114.65098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Effervescing Elephant","status":200,"ts":1542553178796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":30,"lastName":"Lynch","length":167.6273,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"If You Want To Sing Out_ Sing Out","status":200,"ts":1542553292796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Cosmic Gate","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":0,"lastName":"Summers","length":652.59057,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":675,"song":"I Feel Wonderful (AM to PM Mix)","status":200,"ts":1542553336796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Spoon","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":31,"lastName":"Lynch","length":224.73098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Who Makes Your Money","status":200,"ts":1542553459796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Dodos","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":32,"lastName":"Lynch","length":282.53995,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Fools","status":200,"ts":1542553683796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Cartola","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":33,"lastName":"Lynch","length":127.242,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Tive Sim","status":200,"ts":1542553965796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Supertramp","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":34,"lastName":"Lynch","length":264.38485,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"It's Raining Again","status":200,"ts":1542554092796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Ruts","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":35,"lastName":"Lynch","length":338.96444,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"West One (Shine On Me)","status":200,"ts":1542554356796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Marisa Monte","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":36,"lastName":"Lynch","length":157.98812,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Abololo","status":200,"ts":1542554694796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Smile Empty Soul","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":37,"lastName":"Lynch","length":218.61832,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Bottom of a Bottle (Explicit Album Version)","status":200,"ts":1542554851796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"M83","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":38,"lastName":"Lynch","length":251.79383,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Unrecorded","status":200,"ts":1542555069796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Beats Antique","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":39,"lastName":"Lynch","length":185.46893,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Roustabout (Bassnectar REMIX)","status":200,"ts":1542555320796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Why?","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":40,"lastName":"Lynch","length":246.07302,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"The Vowels Pt. 2","status":200,"ts":1542555505796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Chris Clark","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":41,"lastName":"Lynch","length":162.11546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"From Head To Toe","status":200,"ts":1542555751796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Concretes","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":42,"lastName":"Lynch","length":195.082,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"On The Radio (Edit)","status":200,"ts":1542555913796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":43,"lastName":"Lynch","length":261.74649,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Halo","status":200,"ts":1542556108796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Enya","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":44,"lastName":"Lynch","length":218.53995,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Only Time (Original Version)","status":200,"ts":1542556369796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"C\u00c3\u0083\u00c2\u00a9line Dion","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":45,"lastName":"Lynch","length":219.37587,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Ne me plaignez pas","status":200,"ts":1542556587796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Rise Against","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":46,"lastName":"Lynch","length":245.96853,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Audience Of One","status":200,"ts":1542556806796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kaiser Chiefs","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":47,"lastName":"Lynch","length":203.07546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Ruby","status":200,"ts":1542557051796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Jag Panzer","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":48,"lastName":"Lynch","length":217.99138,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Reign Of The Tyrants","status":200,"ts":1542557254796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"My Chemical Romance","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":49,"lastName":"Lynch","length":203.41506,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"The Ghost Of You (Album Version)","status":200,"ts":1542557471796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Zeromancer","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":50,"lastName":"Lynch","length":360.85506,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Cupola","status":200,"ts":1542557674796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Cardigans","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":51,"lastName":"Lynch","length":197.38077,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Losers","status":200,"ts":1542558034796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Future Rock","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":52,"lastName":"Lynch","length":239.90812,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Gears","status":200,"ts":1542558231796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Lady GaGa","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":53,"lastName":"Lynch","length":274.18077,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Alejandro","status":200,"ts":1542558470796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":686,"song":null,"status":200,"ts":1542558612796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Keyshia Cole","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":54,"lastName":"Lynch","length":227.60444,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Superstar","status":200,"ts":1542558744796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Big Star","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":55,"lastName":"Lynch","length":203.51955,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"When My Baby's Beside Me","status":200,"ts":1542558971796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Armin van Buuren","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":435.51302,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":686,"song":"Hold On To Me","status":200,"ts":1542559056796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Harmonia","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":56,"lastName":"Lynch","length":655.77751,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Sehr kosmisch","status":200,"ts":1542559174796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Jermaine Jackson","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":57,"lastName":"Lynch","length":206.8371,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"I Need You","status":200,"ts":1542559829796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Sons Of the Pioneers","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":58,"lastName":"Lynch","length":175.59465,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Cool Water","status":200,"ts":1542560035796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Ti\u00c3\u0083\u00c2\u00absto","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":59,"lastName":"Lynch","length":231.73179,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"In The Dark (ft. Christian Burns)","status":200,"ts":1542560210796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"U2","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":60,"lastName":"Lynch","length":247.66649,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Window In The Skies","status":200,"ts":1542560441796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kanye West \/ Nas \/ Really Doe","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":61,"lastName":"Lynch","length":448.57424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"We Major","status":200,"ts":1542560688796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Radney Foster","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":62,"lastName":"Lynch","length":288.96608,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Sweet And Wild","status":200,"ts":1542561136796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Binary Star","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":63,"lastName":"Lynch","length":268.93016,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Solar Powered","status":200,"ts":1542561424796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Eminem","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":64,"lastName":"Lynch","length":284.18567,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"The Real Slim Shady","status":200,"ts":1542561692796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Sick Puppies","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":65,"lastName":"Lynch","length":248.58077,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"What Are You Looking For","status":200,"ts":1542561976796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":66,"lastName":"Lynch","length":224.67873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Secrets","status":200,"ts":1542562224796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Say Anything","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":67,"lastName":"Lynch","length":180.03546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Wow_ I Can Get Sexual Too","status":200,"ts":1542562448796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Nine Inch Nails","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":68,"lastName":"Lynch","length":179.06893,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"A Warm Place","status":200,"ts":1542562628796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Bebe","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":69,"lastName":"Lynch","length":234.762,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"El Golpe","status":200,"ts":1542562807796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Pennywise","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":70,"lastName":"Lynch","length":138.05669,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Waste of Time","status":200,"ts":1542563041796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Justice","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":71,"lastName":"Lynch","length":265.16853,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Waters Of Nazareth (album version)","status":200,"ts":1542563179796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Panic At The Disco","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":72,"lastName":"Lynch","length":259.29098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Behind The Sea [Live In Chicago]","status":200,"ts":1542563444796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Los L\u00c3\u0083\u00c2\u00a1tigos","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":73,"lastName":"Lynch","length":122.17424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Besos Y Caricias","status":200,"ts":1542563703796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Sick Puppies","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":74,"lastName":"Lynch","length":209.44934,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Maybe","status":200,"ts":1542563825796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"David Crowder*Band","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":75,"lastName":"Lynch","length":165.14567,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"I Saw The Light","status":200,"ts":1542564034796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Supersister","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":76,"lastName":"Lynch","length":606.06649,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"A Girl Named You","status":200,"ts":1542564199796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Faith No More","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":77,"lastName":"Lynch","length":249.86077,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Last Cup Of Sorrow","status":200,"ts":1542564805796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Jet Black Stare","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":78,"lastName":"Lynch","length":211.30404,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Rearview Mirror","status":200,"ts":1542565054796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":79,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":589,"song":null,"status":200,"ts":1542565113796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Muse","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":80,"lastName":"Lynch","length":209.50159,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Supermassive Black Hole (Twilight Soundtrack Version)","status":200,"ts":1542565265796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Nikka Costa","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":81,"lastName":"Lynch","length":228.46649,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Just Because","status":200,"ts":1542565474796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":82,"lastName":"Lynch","length":139.51955,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"I'll Be Your Man","status":200,"ts":1542565702796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Expos\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":83,"lastName":"Lynch","length":249.41669,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Let Me Be The One","status":200,"ts":1542565841796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Otis Rush","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":84,"lastName":"Lynch","length":142.62812,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Sit Down Baby","status":200,"ts":1542566090796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Wavves","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":85,"lastName":"Lynch","length":193.59302,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"So Bored","status":200,"ts":1542566232796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Taking Back Sunday","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":86,"lastName":"Lynch","length":234.08281,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"The Ballad Of Sal Villanueva (Album Version)","status":200,"ts":1542566425796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Apocalyptica","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":87,"lastName":"Lynch","length":206.15791,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Quutamo","status":200,"ts":1542566659796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Reel Big Fish","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":88,"lastName":"Lynch","length":158.51057,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Turn The Radio Off","status":200,"ts":1542566865796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Love Shop","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":89,"lastName":"Lynch","length":308.1922,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"En Nat Bliver Det Sommer","status":200,"ts":1542567023796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Erin McKeown","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":90,"lastName":"Lynch","length":338.46812,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Fast As I Can","status":200,"ts":1542567331796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Deadmau5","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":91,"lastName":"Lynch","length":463.04608,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Slip","status":200,"ts":1542567669796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":92,"lastName":"Lynch","length":322.2722,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"The Garden","status":200,"ts":1542568132796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Dntel","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":93,"lastName":"Lynch","length":226.82077,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"I'd Like To Know","status":200,"ts":1542568454796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Faron Young","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":94,"lastName":"Lynch","length":135.31383,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Hello Walls","status":200,"ts":1542568680796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Fonseca","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":95,"lastName":"Lynch","length":276.03546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Como Me Mira","status":200,"ts":1542568815796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Platero Y Tu","auth":"Logged In","firstName":"Magdalene","gender":"F","itemInSession":0,"lastName":"Herman","length":133.61587,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540766630796.0,"sessionId":656,"song":"Imanol","status":200,"ts":1542569033796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"77"} {"artist":"Goldfrapp","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":96,"lastName":"Lynch","length":285.36118,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Beautiful","status":200,"ts":1542569091796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Simon Harris","auth":"Logged In","firstName":"Magdalene","gender":"F","itemInSession":1,"lastName":"Herman","length":195.83955,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540766630796.0,"sessionId":656,"song":"Sample Track 2","status":200,"ts":1542569166796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"77"} {"artist":"Hoobastank","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":97,"lastName":"Lynch","length":202.57914,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Up And Gone","status":200,"ts":1542569376796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Various Artists - Delicious Vinyl","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":98,"lastName":"Lynch","length":264.25424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Bust A Move","status":200,"ts":1542569578796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Buena Vista Social Club","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":99,"lastName":"Lynch","length":174.28853,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"La Bayamesa","status":200,"ts":1542569842796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Train","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":100,"lastName":"Lynch","length":205.45261,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Marry Me","status":200,"ts":1542570016796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":101,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":589,"song":null,"status":200,"ts":1542570124796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Diam's","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":102,"lastName":"Lynch","length":250.72281,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Dans Ma Bulle (Edit Radio - Live 2006)","status":200,"ts":1542570221796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Seal","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":103,"lastName":"Lynch","length":288.9922,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"The Beginning (Single Remix)","status":200,"ts":1542570471796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Flying Lotus","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":104,"lastName":"Lynch","length":191.16363,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Hello","status":200,"ts":1542570759796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Belouis Some","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":105,"lastName":"Lynch","length":331.15383,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Imagination (12'' Version)","status":200,"ts":1542570950796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":695,"song":null,"status":200,"ts":1542570995796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Estuera","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":505.44281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":695,"song":"Palma Solane","status":200,"ts":1542571143796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Fray","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":106,"lastName":"Lynch","length":256.60036,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Never Say Never","status":200,"ts":1542571281796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Muse","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":107,"lastName":"Lynch","length":223.63383,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Sunburn [Live]","status":200,"ts":1542571537796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Libertines","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":160.39138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":695,"song":"Up The Bracket","status":200,"ts":1542571648796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":108,"lastName":"Lynch","length":233.89995,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Love Story","status":200,"ts":1542571760796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Bobby Lee","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":109,"lastName":"Lynch","length":247.43138,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Be Aware","status":200,"ts":1542571993796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Great White","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":110,"lastName":"Lynch","length":357.14567,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"House Of Broken Love","status":200,"ts":1542572240796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Help","registration":1540940782796.0,"sessionId":695,"song":null,"status":200,"ts":1542572319796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":111,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":589,"song":null,"status":200,"ts":1542572342796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Boys Noize","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":112,"lastName":"Lynch","length":330.762,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Don\u00c3\u0082\u00c2\u00b4t Believe The Hype","status":200,"ts":1542572597796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Katy Perry","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":113,"lastName":"Lynch","length":179.40853,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"I Kissed A Girl","status":200,"ts":1542572927796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Platero Y Tu","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":114,"lastName":"Lynch","length":133.61587,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Imanol","status":200,"ts":1542573106796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kim Carnes","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":115,"lastName":"Lynch","length":217.28608,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Crazy In The Night (Barking At Airplanes)","status":200,"ts":1542573239796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Apollo 100","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":116,"lastName":"Lynch","length":163.42159,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Joy","status":200,"ts":1542573456796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Downgrade","registration":1540940782796.0,"sessionId":695,"song":null,"status":200,"ts":1542573462796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":117,"lastName":"Lynch","length":191.76444,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Howlin\u0019 For You","status":200,"ts":1542573619796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Gorod","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":118,"lastName":"Lynch","length":291.02975,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Disavow your God (Album Version)","status":200,"ts":1542573810796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":119,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"Logout","registration":1540223723796.0,"sessionId":589,"song":null,"status":307,"ts":1542573811796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":120,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":589,"song":null,"status":200,"ts":1542573858796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":121,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":589,"song":null,"status":307,"ts":1542573859796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":122,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":589,"song":null,"status":200,"ts":1542573942796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":123,"lastName":"Lynch","length":264.82893,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Monsoon","status":200,"ts":1542574101796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"M.I.A.","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":206.13179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":695,"song":"Paper Planes","status":200,"ts":1542574281796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Caribou","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":124,"lastName":"Lynch","length":315.48036,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Odessa","status":200,"ts":1542574365796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Missy Elliott","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":256.54812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":695,"song":"Meltdown (Amended Album Version)","status":200,"ts":1542574487796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Los Originales De San Juan","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":125,"lastName":"Lynch","length":156.73424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"El Infeliz","status":200,"ts":1542574680796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Michael Bubl\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":152.08444,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":695,"song":"All I Do Is Dream Of You (Album Version)","status":200,"ts":1542574743796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Weezer","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":126,"lastName":"Lynch","length":139.65016,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":589,"song":"Photograph","status":200,"ts":1542574836796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Gary Stewart","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":182.67383,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":695,"song":"Back Sliders Wine","status":200,"ts":1542574895796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":127,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Downgrade","registration":1540223723796.0,"sessionId":589,"song":null,"status":200,"ts":1542575011796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":null,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"GET","page":"Home","registration":1540829025796.0,"sessionId":687,"song":null,"status":200,"ts":1542582161796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Travie McCoy","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":211.12118,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":687,"song":"Billionaire [feat. Bruno Mars] (Explicit Album Version)","status":200,"ts":1542582164796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"}
481.573248
557
0.69852
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":689,"song":null,"status":200,"ts":1542592468796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Explosions In The Sky","auth":"Logged In","firstName":"Adelyn","gender":"F","itemInSession":0,"lastName":"Jordan","length":497.47546,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1540130971796.0,"sessionId":458,"song":"Your Hand In Mine","status":200,"ts":1542592496796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"7"} {"artist":null,"auth":"Logged In","firstName":"Adelyn","gender":"F","itemInSession":1,"lastName":"Jordan","length":null,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"Logout","registration":1540130971796.0,"sessionId":458,"song":null,"status":307,"ts":1542592497796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"7"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":458,"song":null,"status":200,"ts":1542592500796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":458,"song":null,"status":307,"ts":1542592501796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Adelyn","gender":"F","itemInSession":4,"lastName":"Jordan","length":null,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1540130971796.0,"sessionId":458,"song":null,"status":200,"ts":1542592516796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"7"} {"artist":"Paul Van Dyk Featuring Jessica Sutta","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":0,"lastName":"Griffin","length":425.66485,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"White Lies (Dave Spoon Remix)","status":200,"ts":1542592893796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Tim Hughes","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":1,"lastName":"Griffin","length":323.47383,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"God of Justice","status":200,"ts":1542593318796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"David Cassidy & The Partridge Family","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":2,"lastName":"Griffin","length":227.73506,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"I'll Meet You Halfway","status":200,"ts":1542593641796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Snow Patrol","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":3,"lastName":"Griffin","length":200.93342,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Crack The Shutters","status":200,"ts":1542593868796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Third Eye Blind","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":4,"lastName":"Griffin","length":347.11465,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Darwin","status":200,"ts":1542594068796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"HYPOCRISY","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":5,"lastName":"Griffin","length":331.38893,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"The Quest","status":200,"ts":1542594415796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Peccatum","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":6,"lastName":"Griffin","length":283.0624,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"And Pray For Me","status":200,"ts":1542594746796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Justyna Steczkowska","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":7,"lastName":"Griffin","length":333.53098,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Noc...","status":200,"ts":1542595029796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bloc Party","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":8,"lastName":"Griffin","length":259.36934,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Your Visits Are Getting Shorter","status":200,"ts":1542595362796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":562,"song":null,"status":200,"ts":1542595539796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"About","registration":null,"sessionId":562,"song":null,"status":200,"ts":1542595571796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":562,"song":null,"status":307,"ts":1542595572796,"userAgent":null,"userId":""} {"artist":"Temprees","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":9,"lastName":"Griffin","length":177.34485,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"At Last","status":200,"ts":1542595621796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":3,"lastName":"Johnson","length":null,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"GET","page":"Home","registration":1541081807796.0,"sessionId":562,"song":null,"status":200,"ts":1542595632796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"Mickie Krause","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":10,"lastName":"Griffin","length":204.17261,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Orange Tr\u00c3\u0083\u00c2\u00a4gt Nur Die M\u00c3\u0083\u00c2\u00bcllabfuhr (Go West)","status":200,"ts":1542595798796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Foolish Things","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":11,"lastName":"Griffin","length":266.86649,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Who Can Compare","status":200,"ts":1542596002796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bersuit Vergarabat","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":12,"lastName":"Griffin","length":289.30567,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Hecho En Buenos Aires","status":200,"ts":1542596268796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Man\u00c3\u0083\u00c2\u00a1","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":13,"lastName":"Griffin","length":262.81751,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Mariposa traicionera","status":200,"ts":1542596557796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Newton Faulkner","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":14,"lastName":"Griffin","length":190.04036,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Feels Like Home","status":200,"ts":1542596819796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":15,"lastName":"Griffin","length":260.25751,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Come To Me","status":200,"ts":1542597009796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Olivia Newton-John","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":16,"lastName":"Griffin","length":132.23138,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Hochmah (Interlude)","status":200,"ts":1542597269796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"David Byrne & Fatboy Slim feat. Charmaine Clamor","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":17,"lastName":"Griffin","length":238.65424,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Walk Like A Woman (Album Version)","status":200,"ts":1542597401796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Lords Of The New Church","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":18,"lastName":"Griffin","length":182.36036,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Girls Girls Girls","status":200,"ts":1542597639796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Harry Chapin","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":19,"lastName":"Griffin","length":406.15138,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Taxi (LP Version)","status":200,"ts":1542597821796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Jimmy Eat World","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":20,"lastName":"Griffin","length":166.00771,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"The Middle","status":200,"ts":1542598227796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Now It's Overhead","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":21,"lastName":"Griffin","length":267.04934,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Profile (Album Version)","status":200,"ts":1542598393796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":22,"lastName":"Griffin","length":348.57751,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Undo","status":200,"ts":1542598660796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"THE CHIFFONS","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":23,"lastName":"Griffin","length":124.682,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"I Have A Boyfriend","status":200,"ts":1542599008796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":24,"lastName":"Griffin","length":293.14567,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Dangerously In Love","status":200,"ts":1542599132796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Roxy Music","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":25,"lastName":"Griffin","length":269.5571,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"More Than This","status":200,"ts":1542599425796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Tokio Hotel","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":26,"lastName":"Griffin","length":191.89506,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Nach dir kommt nichts","status":200,"ts":1542599694796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Coldplay","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":27,"lastName":"Griffin","length":274.41587,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"One I Love","status":200,"ts":1542599885796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":676,"song":null,"status":200,"ts":1542599901796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":676,"song":null,"status":307,"ts":1542599902796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":2,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"GET","page":"Home","registration":1540006905796.0,"sessionId":676,"song":null,"status":200,"ts":1542600031796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Lou Gramm","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":3,"lastName":"Arellano","length":296.17587,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":676,"song":"Just Between You And Me (Remastered LP Version)","status":200,"ts":1542600047796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Aesop Rock","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":28,"lastName":"Griffin","length":272.24771,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"One Brick","status":200,"ts":1542600159796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Mars Volta","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":29,"lastName":"Griffin","length":426.00444,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Drunkship Of Lanterns","status":200,"ts":1542600431796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Jonna Tervomaa","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":30,"lastName":"Griffin","length":219.97669,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Kaiken se k\u00c3\u0083\u00c2\u00a4rsii","status":200,"ts":1542600857796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":31,"lastName":"Griffin","length":231.81016,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Use Somebody","status":200,"ts":1542601076796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"LMFAO \/ Lil Jon","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":32,"lastName":"Griffin","length":222.17098,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Shots","status":200,"ts":1542601307796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Global Deejays Feat. Rozalla","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":398.52363,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":684,"song":"Everybody\u00c3\u0082\u00c2\u00b4s Free","status":200,"ts":1542601482796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Ratt","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":33,"lastName":"Griffin","length":195.86567,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Scratch That Itch (LP Version)","status":200,"ts":1542601529796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":34,"lastName":"Griffin","length":201.79546,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Revelry","status":200,"ts":1542601724796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"N.E.R.D.","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":35,"lastName":"Griffin","length":259.23873,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Rock Star","status":200,"ts":1542601925796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Future Rock","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Koch","length":239.90812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":612,"song":"Gears","status":200,"ts":1542602170796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Pride Tiger","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":36,"lastName":"Griffin","length":215.77098,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"The Lucky Ones","status":200,"ts":1542602184796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Lady GaGa \/ Colby O'Donis","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":37,"lastName":"Griffin","length":238.54975,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Just Dance","status":200,"ts":1542602399796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Koch","length":216.92036,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":612,"song":"In The End (Album Version)","status":200,"ts":1542602409796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Rapper K","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Koch","length":328.51546,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":612,"song":"Moving Forward (feat. Late_ M.E.N.I.S. & Caper)","status":200,"ts":1542602625796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Nevermore","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":38,"lastName":"Griffin","length":253.1522,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"I Am The Dog","status":200,"ts":1542602637796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Phoenix","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":39,"lastName":"Griffin","length":198.03383,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Too Young","status":200,"ts":1542602890796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Mt. St. Helens Vietnam Band","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Koch","length":253.6224,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":612,"song":"A Year Or Two","status":200,"ts":1542602953796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Justice","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":40,"lastName":"Griffin","length":242.23302,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"D.A.N.C.E. [Live Version]","status":200,"ts":1542603088796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Koch","length":201.32526,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":612,"song":"Joe's Head","status":200,"ts":1542603206796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"A Skylit Drive","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":41,"lastName":"Griffin","length":206.18404,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"City On The Edge Of Forever","status":200,"ts":1542603330796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Muse","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":5,"lastName":"Koch","length":346.69669,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":612,"song":"Resistance","status":200,"ts":1542603407796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Superlitio","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":42,"lastName":"Griffin","length":226.79465,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Te Lastim\u00c3\u0083\u00c2\u00a9","status":200,"ts":1542603536796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Meteors","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":6,"lastName":"Koch","length":142.21016,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":612,"song":"Yellow Zone","status":200,"ts":1542603753796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Ray Barretto","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":43,"lastName":"Griffin","length":251.79383,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Indestructible","status":200,"ts":1542603762796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Lonely Island \/ Justin Timberlake","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":7,"lastName":"Koch","length":161.01832,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":612,"song":"Dick In A Box","status":200,"ts":1542603895796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":44,"lastName":"Griffin","length":302.91546,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"What If I Do?","status":200,"ts":1542604013796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"LMFAO","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":8,"lastName":"Koch","length":227.99628,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":612,"song":"I'm In Miami Bitch","status":200,"ts":1542604056796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Avenged Sevenfold","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":9,"lastName":"Koch","length":426.13506,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":612,"song":"Shattered By Broken Dreams","status":200,"ts":1542604283796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":10,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"Logout","registration":1541048010796.0,"sessionId":612,"song":null,"status":307,"ts":1542604284796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":11,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":612,"song":null,"status":200,"ts":1542604296796,"userAgent":null,"userId":""} {"artist":"The Thrills","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":45,"lastName":"Griffin","length":332.9824,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Hollywood Kids","status":200,"ts":1542604315796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Patty Larkin","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":46,"lastName":"Griffin","length":220.1073,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Don't","status":200,"ts":1542604647796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Coldplay","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":47,"lastName":"Griffin","length":298.762,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Shiver","status":200,"ts":1542604867796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Coldplay","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":48,"lastName":"Griffin","length":268.38159,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Yellow","status":200,"ts":1542605165796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":49,"lastName":"Griffin","length":192.73098,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Crazier","status":200,"ts":1542605433796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Brad Paisley With Andy Griffith","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":302.70649,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":681,"song":"Waitin' On A Woman","status":200,"ts":1542605560796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Fruko Y Sus Tesos","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":50,"lastName":"Griffin","length":261.11955,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"El Presidiario","status":200,"ts":1542605625796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Fats Domino","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":51,"lastName":"Griffin","length":122.98404,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Be My Guest","status":200,"ts":1542605886796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Crippled Black Phoenix","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":52,"lastName":"Griffin","length":434.78159,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"A Lack of Common Sense","status":200,"ts":1542606008796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":53,"lastName":"Griffin","length":348.57751,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Undo","status":200,"ts":1542606442796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":666,"song":null,"status":307,"ts":1542606721796,"userAgent":null,"userId":""} {"artist":"The Kills","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":54,"lastName":"Griffin","length":203.38893,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Last Day Of Magic","status":200,"ts":1542606790796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Lady GaGa \/ Colby O'Donis","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":55,"lastName":"Griffin","length":238.54975,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Just Dance","status":200,"ts":1542606993796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Kanye West","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":56,"lastName":"Griffin","length":237.47873,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Flashing Lights","status":200,"ts":1542607231796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"M83","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":57,"lastName":"Griffin","length":234.47465,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Noise","status":200,"ts":1542607468796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Kix","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":58,"lastName":"Griffin","length":246.25587,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Girl Money","status":200,"ts":1542607702796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Beatnuts","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":59,"lastName":"Griffin","length":267.36281,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"World Famous","status":200,"ts":1542607948796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":666,"song":null,"status":200,"ts":1542608077796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Foreign Exchange","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":60,"lastName":"Griffin","length":249.20771,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"All That You Are (Instrumental)","status":200,"ts":1542608215796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":61,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":672,"song":null,"status":200,"ts":1542608229796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The View","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":62,"lastName":"Griffin","length":249.49506,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Double Yellow Lines","status":200,"ts":1542608464796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Britney Spears","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":197.09342,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":666,"song":"(You Drive Me) Crazy (The Stop Remix!)","status":200,"ts":1542608571796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"New Young Pony Club","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":63,"lastName":"Griffin","length":287.89506,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Architect Of Love","status":200,"ts":1542608713796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Hot Chip","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":240.37832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":666,"song":"Beach Party","status":200,"ts":1542608768796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kanye West","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":64,"lastName":"Griffin","length":311.84934,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Stronger","status":200,"ts":1542609000796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":253.25669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":666,"song":"Good Life","status":200,"ts":1542609008796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Tom Petty And The Heartbreakers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":173.322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":666,"song":"Baby's A Rock 'N' Roller (Album Version)","status":200,"ts":1542609261796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"Logout","registration":1540794356796.0,"sessionId":666,"song":null,"status":307,"ts":1542609262796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Everclear","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":65,"lastName":"Griffin","length":172.22485,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Heartspark Dollarsign","status":200,"ts":1542609311796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Phil Collins","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":66,"lastName":"Griffin","length":175.12444,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"You Can't Hurry Love","status":200,"ts":1542609483796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Sister Hazel","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":67,"lastName":"Griffin","length":243.25179,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Where Do You Go","status":200,"ts":1542609658796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":68,"lastName":"Griffin","length":239.3073,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"You're The One","status":200,"ts":1542609901796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Ruts","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":69,"lastName":"Griffin","length":338.96444,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"West One (Shine On Me)","status":200,"ts":1542610140796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":7,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":666,"song":null,"status":200,"ts":1542610338796,"userAgent":null,"userId":""} {"artist":"Evil Nine","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":70,"lastName":"Griffin","length":232.9073,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"The Wait (Feat. David Autokratz)","status":200,"ts":1542610478796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":71,"lastName":"Griffin","length":229.19791,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Hard Headed Woman","status":200,"ts":1542610710796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The B-52's","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":72,"lastName":"Griffin","length":321.54077,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Love Shack","status":200,"ts":1542610939796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Cheb Mami","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":73,"lastName":"Griffin","length":229.32853,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"A'rabti","status":200,"ts":1542611260796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":8,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":666,"song":null,"status":200,"ts":1542611338796,"userAgent":null,"userId":""} {"artist":"matchbox twenty","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":74,"lastName":"Griffin","length":229.14567,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Unwell (Album Version)","status":200,"ts":1542611489796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Depeche Mode","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":75,"lastName":"Griffin","length":295.20934,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Personal Jesus","status":200,"ts":1542611718796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Coheed and Cambria","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":76,"lastName":"Griffin","length":563.82649,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"The Light & The Glass","status":200,"ts":1542612013796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bob Lind","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":77,"lastName":"Griffin","length":167.83628,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Elusive Butterfly","status":200,"ts":1542612576796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Nightwish","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":78,"lastName":"Griffin","length":321.98485,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Astral Romance","status":200,"ts":1542612743796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Old 97's","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":79,"lastName":"Griffin","length":188.73424,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Timebomb (LP Version)","status":200,"ts":1542613064796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Young Money featuring Lloyd","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":80,"lastName":"Griffin","length":196.33587,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"BedRock (Radio Edit) (feat.Lloyd)","status":200,"ts":1542613252796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Blind Guardian","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":81,"lastName":"Griffin","length":218.22649,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"The Eldar (Remastered)","status":200,"ts":1542613448796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Stone Sour","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":82,"lastName":"Griffin","length":203.67628,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Made Of Scars (Album Version)","status":200,"ts":1542613666796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":83,"lastName":"Griffin","length":239.80363,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Face To Face","status":200,"ts":1542613869796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"La Rue K\u00c3\u0083\u00c2\u00a9tanou","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":84,"lastName":"Griffin","length":213.08036,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Les hommes que j'aime","status":200,"ts":1542614108796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"James Blake","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":287.00689,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":706,"song":"Footnotes","status":200,"ts":1542614180796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Alex Ubago","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":85,"lastName":"Griffin","length":249.41669,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"No Te Rindas","status":200,"ts":1542614321796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Metallica","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":86,"lastName":"Griffin","length":515.21261,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Master Of Puppets","status":200,"ts":1542614570796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"September Malevolence","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":87,"lastName":"Griffin","length":823.74485,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Nobody Noticed The Fire","status":200,"ts":1542615085796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Morcheeba","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":0,"lastName":"Benson","length":360.48934,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":579,"song":"Big Calm","status":200,"ts":1542615450796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"The Duckworth Lewis Method","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":1,"lastName":"Benson","length":258.16771,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":579,"song":"Flatten the Hay","status":200,"ts":1542615810796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"CSS","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":88,"lastName":"Griffin","length":213.75955,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Let's Make Love And Listen To Death From Above [Dan Carey Mix] (remastered album version)","status":200,"ts":1542615908796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Stars","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":2,"lastName":"Benson","length":243.1473,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":579,"song":"Elevator Love Letter","status":200,"ts":1542616068796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":89,"lastName":"Griffin","length":211.01669,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Tighten Up","status":200,"ts":1542616121796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":0,"lastName":"Gutierrez","length":null,"level":"free","location":"Columbia, SC","method":"GET","page":"Home","registration":1540809335796.0,"sessionId":467,"song":null,"status":200,"ts":1542616146796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":1,"lastName":"Gutierrez","length":260.23138,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":467,"song":"Happy Endings","status":200,"ts":1542616148796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Robert Plant","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":90,"lastName":"Griffin","length":226.48118,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"If I Were A Carpenter","status":200,"ts":1542616332796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Gallows","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":91,"lastName":"Griffin","length":479.29424,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Crucifucks (Album Version)","status":200,"ts":1542616558796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Clara Nunes - Com Adoniran Barbosa","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":92,"lastName":"Griffin","length":241.162,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Iracema","status":200,"ts":1542617037796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":0,"lastName":"Santana","length":261.74649,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":599,"song":"Halo","status":200,"ts":1542617114796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Vladislav Delay","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":93,"lastName":"Griffin","length":559.49016,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"I Saw A Polysexual","status":200,"ts":1542617278796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Pierces","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":94,"lastName":"Griffin","length":222.58893,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Three Wishes (Gossip Girl Soundtrack Version)","status":200,"ts":1542617837796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Kelis","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":95,"lastName":"Griffin","length":315.19302,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Mars","status":200,"ts":1542618059796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Linda Eder","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":96,"lastName":"Griffin","length":180.92363,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Don't Rain On My Parade (from Funny Girl) (2007 Remastered LP Version)","status":200,"ts":1542618374796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Airto Moreira","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":97,"lastName":"Griffin","length":306.07628,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Berimbau First Cry","status":200,"ts":1542618554796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Calvin Richardson","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":98,"lastName":"Griffin","length":76.25098,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Intro","status":200,"ts":1542618860796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Craig Mack","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":99,"lastName":"Griffin","length":218.04363,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Flava In Your Ear","status":200,"ts":1542618936796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":100,"lastName":"Griffin","length":257.54077,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Imma Be","status":200,"ts":1542619154796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Remedy Drive","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":101,"lastName":"Griffin","length":185.46893,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"All Along (Album)","status":200,"ts":1542619411796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Jarabe De Palo","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":102,"lastName":"Griffin","length":233.53424,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Como peces en el agua","status":200,"ts":1542619596796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Lunascape","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":103,"lastName":"Griffin","length":376.81587,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Mindstalking (JD Sub's Solid verZion)","status":200,"ts":1542619829796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Krista Detor","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":249.73016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Robert Johnson Has Left Mississippi","status":200,"ts":1542620140796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Happy Mondays","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":104,"lastName":"Griffin","length":208.74404,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Holiday","status":200,"ts":1542620205796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Kaya Project","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":370.65098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Elixir (featuring Omar Farouk Teklibek)","status":200,"ts":1542620389796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cutting Crew","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":105,"lastName":"Griffin","length":293.22404,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Fear Of Falling","status":200,"ts":1542620413796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Downgrade","registration":1540940782796.0,"sessionId":708,"song":null,"status":200,"ts":1542620480796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Less Than Jake","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":106,"lastName":"Griffin","length":154.48771,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":672,"song":"Scott Farcas Takes It On The Chin","status":200,"ts":1542620706796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Chevelle","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":250.06975,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Wonder What's Next","status":200,"ts":1542620759796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Cinematic Orchestra","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":373.9424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"To Build A Home","status":200,"ts":1542621009796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Between The Buried And Me","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":217.75628,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Mirrors","status":200,"ts":1542621382796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kealii Reichel","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":287.65995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Kawaipunahele (Album Version)","status":200,"ts":1542621599796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":233.69098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Invalid","status":200,"ts":1542621886796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Joe Christmas","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":185.7824,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Bedroom Suite","status":200,"ts":1542622119796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Die Mooskirchner","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":169.29914,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Frisch und g'sund","status":200,"ts":1542622304796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Devendra Banhart","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":150.41261,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Todo Los Dolores","status":200,"ts":1542622473796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Method Man \/ Ghostface Killah \/ Solomon Childs \/ Streetlife","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":177.13587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Smooth Sailing Remix","status":200,"ts":1542622623796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Live","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":231.78404,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"The Distance","status":200,"ts":1542622800796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kansas","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":337.26649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Look At The Time","status":200,"ts":1542623031796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Alain Clark","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":219.27138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"I Need You (Album)","status":200,"ts":1542623368796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bright Eyes","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":224.80934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"At The Bottom Of Everything","status":200,"ts":1542623587796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Devendra Banhart","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":97.43628,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"My Ships","status":200,"ts":1542623811796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"John Michael Montgomery","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":17,"lastName":"Cuevas","length":234.29179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"I Can Love You Like That (Remastered Version)","status":200,"ts":1542623908796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Pink Fairies","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":18,"lastName":"Cuevas","length":236.40771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"The Snake","status":200,"ts":1542624142796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Simon Harris","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":19,"lastName":"Cuevas","length":195.83955,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Sample Track 2","status":200,"ts":1542624378796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":20,"lastName":"Cuevas","length":224.67873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Secrets","status":200,"ts":1542624573796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Greg Adams","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":21,"lastName":"Cuevas","length":285.57016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Wrapped Around Your Finger","status":200,"ts":1542624797796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Colbie Caillat","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":22,"lastName":"Cuevas","length":233.16853,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"I Never Told You","status":200,"ts":1542625082796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":23,"lastName":"Cuevas","length":189.25669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Stab My Back","status":200,"ts":1542625315796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Third Day","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":24,"lastName":"Cuevas","length":279.17016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"God of Wonders","status":200,"ts":1542625504796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Toby Keith","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":25,"lastName":"Cuevas","length":243.69587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Weed With Willie","status":200,"ts":1542625783796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Coldplay","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":26,"lastName":"Cuevas","length":327.8624,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Daylight","status":200,"ts":1542626026796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Freefall Feat. Jan Johnston","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":27,"lastName":"Cuevas","length":532.11383,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":708,"song":"Skydive (I Feel Wonderful)","status":200,"ts":1542626353796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Roger Cicero","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":176.97914,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":719,"song":"Frauen regier'n die Welt","status":200,"ts":1542626835796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Lady GaGa \/ Colby O'Donis","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":238.54975,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":719,"song":"Just Dance","status":200,"ts":1542627011796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Hot Chip","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":283.32363,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":688,"song":"We're Looking For A Lot Of Love","status":200,"ts":1542629885796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":711,"song":null,"status":200,"ts":1542630756796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Tenth Avenue North","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":245.34159,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":711,"song":"Love Is Here","status":200,"ts":1542630768796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":678,"song":null,"status":200,"ts":1542631305796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":null,"level":"free","location":"Santa Rosa, CA","method":"GET","page":"Home","registration":1540880381796.0,"sessionId":627,"song":null,"status":200,"ts":1542631587796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"Kid Cudi \/ Ratatat","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":1,"lastName":"Johnson","length":246.72608,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":627,"song":"Alive (nightmare)","status":200,"ts":1542631623796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":null,"auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":0,"lastName":"Garrison","length":null,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"GET","page":"Home","registration":1540832693796.0,"sessionId":700,"song":null,"status":200,"ts":1542631800796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":"Cesaria Evora","auth":"Logged In","firstName":"Makinley","gender":"F","itemInSession":0,"lastName":"Jones","length":241.78893,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541091973796.0,"sessionId":190,"song":"Cabo Verde Mand\u00c3\u0083\u00c2\u00a1 Mant\u00c3\u0083\u00c2\u00a9nha","status":200,"ts":1542633018796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"17"} {"artist":"Iron Maiden","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":227.76118,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":651,"song":"Holy Smoke","status":200,"ts":1542633072796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Angels and Airwaves","auth":"Logged In","firstName":"Makinley","gender":"F","itemInSession":1,"lastName":"Jones","length":302.05342,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541091973796.0,"sessionId":190,"song":"The Gift","status":200,"ts":1542633259796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"17"} {"artist":"Aaron Shust","auth":"Logged In","firstName":"Makinley","gender":"F","itemInSession":2,"lastName":"Jones","length":222.11873,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541091973796.0,"sessionId":190,"song":"Like I Never Felt Before","status":200,"ts":1542633561796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"17"} {"artist":null,"auth":"Logged In","firstName":"Makinley","gender":"F","itemInSession":3,"lastName":"Jones","length":null,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"Logout","registration":1541091973796.0,"sessionId":190,"song":null,"status":307,"ts":1542633562796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"17"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":190,"song":null,"status":200,"ts":1542633598796,"userAgent":null,"userId":""} {"artist":"John Mayer","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":259.16036,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":673,"song":"Wait Until Tomorrow","status":200,"ts":1542634469796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Yes","auth":"Logged In","firstName":"Brayden","gender":"M","itemInSession":0,"lastName":"Clark","length":260.8322,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541029236796.0,"sessionId":477,"song":"TO BE OVER","status":200,"ts":1542635115796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"41"} {"artist":"Brooklyn Bounce","auth":"Logged In","firstName":"Brayden","gender":"M","itemInSession":1,"lastName":"Clark","length":359.13098,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541029236796.0,"sessionId":477,"song":"Get Ready To Bounce Recall 08","status":200,"ts":1542635375796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"41"} {"artist":null,"auth":"Logged In","firstName":"Brayden","gender":"M","itemInSession":2,"lastName":"Clark","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Upgrade","registration":1541029236796.0,"sessionId":477,"song":null,"status":200,"ts":1542635407796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"41"} {"artist":null,"auth":"Logged In","firstName":"Brayden","gender":"M","itemInSession":3,"lastName":"Clark","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1541029236796.0,"sessionId":477,"song":null,"status":200,"ts":1542635420796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"41"} {"artist":"Cold","auth":"Logged In","firstName":"Brayden","gender":"M","itemInSession":4,"lastName":"Clark","length":189.83138,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541029236796.0,"sessionId":477,"song":"Stupid Girl","status":200,"ts":1542635734796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"41"} {"artist":"Parachute","auth":"Logged In","firstName":"Dominick","gender":"M","itemInSession":0,"lastName":"Norris","length":146.05016,"level":"free","location":"Los Angeles-Long Beach-Anaheim, CA","method":"PUT","page":"NextSong","registration":1540975502796.0,"sessionId":403,"song":"She Is Love","status":200,"ts":1542635850796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"45"} {"artist":null,"auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":null,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1541032432796.0,"sessionId":652,"song":null,"status":200,"ts":1542635892796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Ericke","auth":"Logged In","firstName":"Brayden","gender":"M","itemInSession":5,"lastName":"Clark","length":435.93098,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541029236796.0,"sessionId":477,"song":"The Beat Is Rockin (Original Mix)","status":200,"ts":1542635923796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"41"} {"artist":"Weird Al Yankovic","auth":"Logged In","firstName":"Brayden","gender":"M","itemInSession":6,"lastName":"Clark","length":202.47465,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541029236796.0,"sessionId":477,"song":"Amish Paradise (Parody of \"Gangsta's Paradise\" by Coolio)","status":200,"ts":1542636358796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"41"} {"artist":"The Bucketheads","auth":"Logged In","firstName":"Brayden","gender":"M","itemInSession":7,"lastName":"Clark","length":386.97751,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541029236796.0,"sessionId":477,"song":"The Bomb (Little Louie Vega Bonus)","status":200,"ts":1542636560796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"41"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Brayden","gender":"M","itemInSession":8,"lastName":"Clark","length":233.89995,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541029236796.0,"sessionId":477,"song":"Love Story","status":200,"ts":1542636946796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"41"} {"artist":"Jos\u00c3\u0083\u00c2\u00a9 Alfredo Jimenez Con Mariachi Vargas De Tecalitlan","auth":"Logged In","firstName":"Brayden","gender":"M","itemInSession":9,"lastName":"Clark","length":129.27955,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541029236796.0,"sessionId":477,"song":"El Rey","status":200,"ts":1542637179796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"41"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":0,"lastName":"Hayes","length":203.75465,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"When The Lights Go Out","status":200,"ts":1542639633796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Tennessee Ernie Ford","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":1,"lastName":"Hayes","length":157.1522,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"Sixteen Tons","status":200,"ts":1542639836796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Neutral Milk Hotel","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":2,"lastName":"Hayes","length":193.90649,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"Gardenhead \/ Leave Me Alone","status":200,"ts":1542639993796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Don Henley","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":3,"lastName":"Hayes","length":257.41016,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"Through Your Hands (Album Version)","status":200,"ts":1542640186796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Nik B\u00c3\u0083\u00c2\u00a4rtsch's Ronin","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":4,"lastName":"Hayes","length":754.72934,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"MODUL 23","status":200,"ts":1542640443796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":724,"song":null,"status":200,"ts":1542641080796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Train","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":270.18404,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":724,"song":"Explanation","status":200,"ts":1542641167796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bright Eyes","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":5,"lastName":"Hayes","length":234.34404,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"Arc Of Time (time Code) (Album Version)","status":200,"ts":1542641197796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Usher featuring will.i.am","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":6,"lastName":"Hayes","length":395.72853,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"OMG","status":200,"ts":1542641431796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Kaci Brown","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":201.29914,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":724,"song":"Make You Love Me","status":200,"ts":1542641437796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Todd Barry","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":126.82404,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":724,"song":"Sugar Ray (LP Version)","status":200,"ts":1542641638796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Gob","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":154.17424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":724,"song":"Ming Tran","status":200,"ts":1542641764796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Soltero","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":7,"lastName":"Hayes","length":191.7122,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"Step Through The Door","status":200,"ts":1542641826796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Dropkick Murphys","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":292.25751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":724,"song":"Johnny_ I Hardly Knew Ya","status":200,"ts":1542641918796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"Logout","registration":1540940782796.0,"sessionId":724,"song":null,"status":307,"ts":1542641919796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The (International) Noise Conspiracy","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":8,"lastName":"Hayes","length":217.05098,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"T.I.M.E.B.O.M.B.","status":200,"ts":1542642017796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Theory Of A Deadman","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":9,"lastName":"Hayes","length":211.66975,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"Little Smirk","status":200,"ts":1542642234796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":7,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":724,"song":null,"status":200,"ts":1542642375796,"userAgent":null,"userId":""} {"artist":"Phantom Planet","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":10,"lastName":"Hayes","length":205.06077,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"Do The Panic","status":200,"ts":1542642445796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Panic At The Disco","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":11,"lastName":"Hayes","length":259.29098,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"Behind The Sea [Live In Chicago]","status":200,"ts":1542642650796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Air France","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":12,"lastName":"Hayes","length":192.73098,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"Windmill Wedding","status":200,"ts":1542642909796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":8,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":724,"song":null,"status":200,"ts":1542643049796,"userAgent":null,"userId":""} {"artist":"Green Day","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":13,"lastName":"Hayes","length":185.12934,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"American Idiot [feat. Green Day & The Cast Of American Idiot] (Album Version)","status":200,"ts":1542643101796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":"Sade","auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":14,"lastName":"Hayes","length":236.40771,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1541003367796.0,"sessionId":696,"song":"Nothing Can Come Between Us","status":200,"ts":1542643286796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":null,"auth":"Logged In","firstName":"Jaleah","gender":"F","itemInSession":15,"lastName":"Hayes","length":null,"level":"paid","location":"San Antonio-New Braunfels, TX","method":"GET","page":"Error","registration":1541003367796.0,"sessionId":696,"song":null,"status":404,"ts":1542643307796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"70"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":0,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":723,"song":null,"status":200,"ts":1542643511796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":1,"lastName":"Griffin","length":169.66485,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":723,"song":"Holes To Heaven","status":200,"ts":1542643534796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Ordinary Boys","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":2,"lastName":"Griffin","length":162.87302,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":723,"song":"Boys Will Be Boys","status":200,"ts":1542643703796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Radiohead","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":3,"lastName":"Griffin","length":235.7024,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":723,"song":"Creep (Explicit)","status":200,"ts":1542643865796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Pieces Of A Dream","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":4,"lastName":"Griffin","length":315.79383,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":723,"song":"Ocean View","status":200,"ts":1542644100796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Cartola","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":5,"lastName":"Griffin","length":127.242,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":723,"song":"Tive Sim","status":200,"ts":1542644415796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Epica","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":6,"lastName":"Griffin","length":254.9024,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":723,"song":"Incentive (Bonus Track)","status":200,"ts":1542644542796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Andreas Johnson","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":7,"lastName":"Griffin","length":190.17098,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":723,"song":"A Little Bit Of Love","status":200,"ts":1542644796796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Sam Sparro","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":8,"lastName":"Griffin","length":210.33751,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":723,"song":"Black & Gold","status":200,"ts":1542644986796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Boards of Canada","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":9,"lastName":"Griffin","length":317.70077,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":723,"song":"June 9th","status":200,"ts":1542645196796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Sonny & Cher","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":10,"lastName":"Griffin","length":222.30159,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":723,"song":"What Now My Love (LP Version)","status":200,"ts":1542645513796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Dakota Oak","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":11,"lastName":"Griffin","length":45.63546,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":723,"song":"Baker's Blue Jay Yarn","status":200,"ts":1542645735796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Derek Webb","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":12,"lastName":"Griffin","length":166.19057,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":723,"song":"Please_ Before I Go","status":200,"ts":1542645780796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Hippos","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":13,"lastName":"Griffin","length":127.58159,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":723,"song":"Freeze Up","status":200,"ts":1542645946796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Regina Spektor","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":0,"lastName":"Taylor","length":191.08526,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":702,"song":"The Calculation (Album Version)","status":200,"ts":1542649275796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"Dragonforce","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":473.41669,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":601,"song":"Revolution Deathsquad (Album Version)","status":200,"ts":1542649311796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":1,"lastName":"Taylor","length":252.21179,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":702,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1542649466796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"Dave Hollister","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Smith","length":271.62077,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":601,"song":"One Woman Man","status":200,"ts":1542649784796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":2,"lastName":"Smith","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"Logout","registration":1540306145796.0,"sessionId":601,"song":null,"status":307,"ts":1542649785796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":601,"song":null,"status":200,"ts":1542649927796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":718,"song":null,"status":200,"ts":1542651604796,"userAgent":null,"userId":""} {"artist":"Dave Evans & Thunder Down Under","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":201.01179,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":726,"song":"Somebody Better","status":200,"ts":1542652961796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Los Alegres De Teran","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":164.54485,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":726,"song":"Llore Por Tu Amor","status":200,"ts":1542653162796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Leggo Beast","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":321.93261,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":726,"song":"Itchy Feet","status":200,"ts":1542653326796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Tiamat","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":3,"lastName":"Rodriguez","length":85.73342,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":726,"song":"Diyala","status":200,"ts":1542653647796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":4,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Upgrade","registration":1540511766796.0,"sessionId":726,"song":null,"status":200,"ts":1542653700796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":5,"lastName":"Rodriguez","length":null,"level":"free","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"Submit Upgrade","registration":1540511766796.0,"sessionId":726,"song":null,"status":307,"ts":1542653701796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":6,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":726,"song":null,"status":200,"ts":1542653715796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":0,"lastName":"Cook","length":null,"level":"free","location":"Yuba City, CA","method":"GET","page":"Home","registration":1540679673796.0,"sessionId":683,"song":null,"status":200,"ts":1542653719796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Me In Motion","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":7,"lastName":"Rodriguez","length":156.62975,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":726,"song":"Here In The Middle","status":200,"ts":1542653732796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Andre Hazes","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":1,"lastName":"Cook","length":206.70649,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":683,"song":"Droomland (duet met Paul de Leeuw)","status":200,"ts":1542653752796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Eva Cassidy","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":8,"lastName":"Rodriguez","length":289.56689,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":726,"song":"Autumn Leaves","status":200,"ts":1542653888796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":2,"lastName":"Cook","length":298.762,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":683,"song":"Shiver","status":200,"ts":1542653958796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Blind Melon","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":9,"lastName":"Rodriguez","length":166.39955,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":726,"song":"Walk","status":200,"ts":1542654177796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Andrea","gender":"F","itemInSession":0,"lastName":"Butler","length":null,"level":"free","location":"Pensacola-Ferry Pass-Brent, FL","method":"GET","page":"Home","registration":1541098488796.0,"sessionId":668,"song":null,"status":200,"ts":1542657135796,"userAgent":"Mozilla\/5.0 (X11; Linux x86_64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"90"} {"artist":"Ry Cooder","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":0,"lastName":"Barrett","length":201.56036,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":632,"song":"Corrido de Boxeo","status":200,"ts":1542660040796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Tom Petty","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":1,"lastName":"Barrett","length":263.23546,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":632,"song":"Runnin' Down A Dream","status":200,"ts":1542660241796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Alanis Morissette","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":2,"lastName":"Barrett","length":262.32118,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":632,"song":"Citizen Of The Planet (Album Version)","status":200,"ts":1542660504796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Graham Coxon","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":3,"lastName":"Barrett","length":221.88363,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":632,"song":"Freakin' Out","status":200,"ts":1542660766796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":null,"auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":0,"lastName":"Larson","length":null,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Home","registration":1541045604796.0,"sessionId":624,"song":null,"status":200,"ts":1542660978796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"Carpenters","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":4,"lastName":"Barrett","length":276.06159,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":632,"song":"(They Long To Be) Close To You","status":200,"ts":1542660987796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"The Sugarcubes","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":5,"lastName":"Barrett","length":156.96934,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":632,"song":"Blue Eyed Pop","status":200,"ts":1542661263796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":null,"auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":6,"lastName":"Barrett","length":null,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540685364796.0,"sessionId":632,"song":null,"status":200,"ts":1542661267796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Just Jack","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":1,"lastName":"Larson","length":246.64771,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":624,"song":"Mourning Morning","status":200,"ts":1542661361796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":7,"lastName":"Barrett","length":190.77179,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":632,"song":"Lodi","status":200,"ts":1542661419796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Smile Empty Soul","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":2,"lastName":"Larson","length":224.33914,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":624,"song":"To The Ground","status":200,"ts":1542661607796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":8,"lastName":"Barrett","length":243.48689,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":632,"song":"I'm Yours (Album Version)","status":200,"ts":1542661609796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"RUN-DMC","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":3,"lastName":"Larson","length":182.77832,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":624,"song":"It's Tricky","status":200,"ts":1542661831796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"The Union Underground","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":9,"lastName":"Barrett","length":206.96771,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":632,"song":"Natural High","status":200,"ts":1542661852796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Jay-Jay Johanson","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":4,"lastName":"Larson","length":246.64771,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":624,"song":"Waiting","status":200,"ts":1542662013796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"M.I.A.","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":10,"lastName":"Barrett","length":206.13179,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":632,"song":"Paper Planes","status":200,"ts":1542662058796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Franz Ferdinand","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":5,"lastName":"Larson","length":183.35302,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":624,"song":"Fade Together","status":200,"ts":1542662259796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"Todd Barry","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":11,"lastName":"Barrett","length":126.82404,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":632,"song":"Sugar Ray (LP Version)","status":200,"ts":1542662264796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Rilo Kiley","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":12,"lastName":"Barrett","length":222.06649,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":632,"song":"With Arms Outstretched (Album Version)","status":200,"ts":1542662390796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":null,"auth":"Logged In","firstName":"Braden","gender":"M","itemInSession":0,"lastName":"Parker","length":null,"level":"free","location":"Youngstown-Warren-Boardman, OH-PA","method":"GET","page":"Home","registration":1540999292796.0,"sessionId":570,"song":null,"status":200,"ts":1542663711796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"74"} {"artist":"Paul Simon","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":189.72689,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":703,"song":"The Sound Of Silence","status":200,"ts":1542663834796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Crystal Castles","auth":"Logged In","firstName":"Braden","gender":"M","itemInSession":1,"lastName":"Parker","length":293.8771,"level":"free","location":"Youngstown-Warren-Boardman, OH-PA","method":"PUT","page":"NextSong","registration":1540999292796.0,"sessionId":570,"song":"Year Of Silence","status":200,"ts":1542663899796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"74"} {"artist":"Ultraje A Rigor","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Graves","length":214.282,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"In\u00c3\u0083\u00c2\u00batil","status":200,"ts":1542663919796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Journey","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Graves","length":250.14812,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"When You Love A Woman","status":200,"ts":1542664133796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"John Mayer","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Graves","length":201.16853,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Waiting On The World To Change","status":200,"ts":1542664383796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The Decemberists","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Graves","length":421.85098,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"I Was Meant For the Stage","status":200,"ts":1542664584796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Blue October","auth":"Logged In","firstName":"Ayleen","gender":"F","itemInSession":0,"lastName":"Wise","length":325.90322,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1541085793796.0,"sessionId":212,"song":"Come In Closer","status":200,"ts":1542664655796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_1 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D201 Safari\/9537.53\"","userId":"71"} {"artist":"Priscilla Ahn","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":4,"lastName":"Graves","length":211.64363,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Dream","status":200,"ts":1542665005796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"John Hiatt","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":5,"lastName":"Graves","length":272.06485,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Something Wild","status":200,"ts":1542665216796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Sauce Money Featuring Memphis Bleek","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":6,"lastName":"Graves","length":280.21506,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"What We Do (Explicit) (Feat. Memphis Bleek)","status":200,"ts":1542665488796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Alice Deejay","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":7,"lastName":"Graves","length":216.5024,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Better Off Alone","status":200,"ts":1542665768796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Avenged Sevenfold","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":8,"lastName":"Graves","length":538.30485,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"I Won't See You Tonight Part 1","status":200,"ts":1542665984796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Alejandro Sanz","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":230.24281,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":725,"song":"Non E_ Per Te_ Per Me","status":200,"ts":1542666230796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Black Mountain","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":267.41506,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":725,"song":"Stay Free (Album Version)","status":200,"ts":1542666460796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Tom Petty","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":9,"lastName":"Graves","length":263.23546,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Runnin' Down A Dream","status":200,"ts":1542666522796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Eddie Vedder","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":10,"lastName":"Graves","length":164.17914,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Guaranteed","status":200,"ts":1542666785796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":11,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Home","registration":1540664184796.0,"sessionId":594,"song":null,"status":200,"ts":1542666830796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Alex Party","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":12,"lastName":"Graves","length":229.77261,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Don't Give Me Your Life","status":200,"ts":1542666949796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Mission Of Burma","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":13,"lastName":"Graves","length":188.1073,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Comes Undone","status":200,"ts":1542667178796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Camera Obscura","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":14,"lastName":"Graves","length":229.51138,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"James","status":200,"ts":1542667366796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Enya","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":15,"lastName":"Graves","length":212.32281,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"May It Be (Album version)","status":200,"ts":1542667595796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"R.I.O.","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":16,"lastName":"Graves","length":217.12934,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"When The Sun Comes Down","status":200,"ts":1542667807796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":17,"lastName":"Graves","length":209.52771,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Float On","status":200,"ts":1542668024796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Bill Withers","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":18,"lastName":"Graves","length":383.73832,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Make Love To Your Mind","status":200,"ts":1542668233796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Metallica","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":19,"lastName":"Graves","length":306.46812,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Ain't My Bitch","status":200,"ts":1542668616796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Connar","gender":"M","itemInSession":0,"lastName":"Moreno","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540823606796.0,"sessionId":590,"song":null,"status":200,"ts":1542668802796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10) AppleWebKit\/538.46 (KHTML, like Gecko) Version\/8.0 Safari\/538.46\"","userId":"62"} {"artist":"AFI","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":20,"lastName":"Graves","length":176.48281,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Miseria Cantare--The Beginning","status":200,"ts":1542668922796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Badly Drawn Boy","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":21,"lastName":"Graves","length":306.46812,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Wider Than a Smile","status":200,"ts":1542669098796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Dante Thomas","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":22,"lastName":"Graves","length":217.65179,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Get It On","status":200,"ts":1542669404796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Shinedown","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":23,"lastName":"Graves","length":204.01587,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Heroes (Album Version)","status":200,"ts":1542669621796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":0,"lastName":"Harris","length":null,"level":"free","location":"Eugene, OR","method":"GET","page":"Home","registration":1540906915796.0,"sessionId":682,"song":null,"status":200,"ts":1542669735796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"MGMT","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":1,"lastName":"Harris","length":264.17587,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":682,"song":"Time To Pretend","status":200,"ts":1542669772796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Last Days Of April","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":24,"lastName":"Graves","length":185.39057,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Who's On The Phone?","status":200,"ts":1542669825796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Corinne Bailey Rae","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":25,"lastName":"Graves","length":192.86159,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Another Rainy Day","status":200,"ts":1542670010796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Jos\u00c3\u0083\u00c2\u00a9 Merc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":26,"lastName":"Graves","length":219.24526,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Primavera","status":200,"ts":1542670202796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Lady GaGa","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":27,"lastName":"Graves","length":249.20771,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Monster","status":200,"ts":1542670421796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Javier Ruibal","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":28,"lastName":"Graves","length":286.95465,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Isla Mujeres","status":200,"ts":1542670670796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Finntroll","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":29,"lastName":"Graves","length":280.37179,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"S\u00c3\u0083\u00c2\u00a5ng","status":200,"ts":1542670956796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Nada Surf","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":30,"lastName":"Graves","length":220.57751,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Popular (LP Version)","status":200,"ts":1542671236796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Redbone","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":31,"lastName":"Graves","length":586.21342,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Sizzle Gets It Again","status":200,"ts":1542671456796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"}
460.159021
549
0.698113
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"The Killers","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":32,"lastName":"Graves","length":246.80444,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Read My Mind","status":200,"ts":1542672042796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Tamia","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":33,"lastName":"Graves","length":243.09506,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Officially Missing You (Radio Version)","status":200,"ts":1542672288796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Randy Crawford","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":34,"lastName":"Graves","length":270.75873,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Almaz","status":200,"ts":1542672531796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Frumpies","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":35,"lastName":"Graves","length":134.47791,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Fuck Kitty","status":200,"ts":1542672801796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Julia Fordham","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":36,"lastName":"Graves","length":279.50975,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Girlfriend","status":200,"ts":1542672935796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":37,"lastName":"Graves","length":239.59465,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Unknown Brother","status":200,"ts":1542673214796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Georgia Satellites","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":38,"lastName":"Graves","length":178.88608,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Battleship Chains (LP Version)","status":200,"ts":1542673453796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":39,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Home","registration":1540664184796.0,"sessionId":594,"song":null,"status":200,"ts":1542673602796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"M.I.A.","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":40,"lastName":"Graves","length":206.13179,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Paper Planes","status":200,"ts":1542673631796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Phish","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":41,"lastName":"Graves","length":319.29424,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Prince Caspian","status":200,"ts":1542673837796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Dislocation Dance","auth":"Logged In","firstName":"Maia","gender":"F","itemInSession":0,"lastName":"Burke","length":122.87955,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540676534796.0,"sessionId":628,"song":"With A Smile On Your Face And A Frown In Your Heart","status":200,"ts":1542673957796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"51"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":42,"lastName":"Graves","length":238.62812,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Strange Times","status":200,"ts":1542674156796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"John Hiatt","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":43,"lastName":"Graves","length":242.442,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Have A Little Faith In Me","status":200,"ts":1542674394796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Elvis Costello","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":44,"lastName":"Graves","length":226.0371,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Watching The Detectives","status":200,"ts":1542674636796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Son House","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":45,"lastName":"Graves","length":239.38567,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Death Letter Blues (Live)","status":200,"ts":1542674862796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Cyndi Lauper","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":46,"lastName":"Graves","length":231.81016,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"She Bop","status":200,"ts":1542675101796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"\u00c3\u0083\u00c2\u0089tienne Daho","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":47,"lastName":"Graves","length":231.3922,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Paris Ailleurs (Live 1992)","status":200,"ts":1542675332796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Dragonforce","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":48,"lastName":"Graves","length":345.5473,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Cry of the Brave","status":200,"ts":1542675563796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Rise Against","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":49,"lastName":"Graves","length":242.25914,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Savior","status":200,"ts":1542675908796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Emmy The Great","auth":"Logged In","firstName":"Noah","gender":"M","itemInSession":0,"lastName":"Chavez","length":204.79955,"level":"free","location":"Ogden-Clearfield, UT","method":"PUT","page":"NextSong","registration":1540970748796.0,"sessionId":530,"song":"Mia","status":200,"ts":1542676105796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"94"} {"artist":null,"auth":"Logged In","firstName":"Noah","gender":"M","itemInSession":1,"lastName":"Chavez","length":null,"level":"free","location":"Ogden-Clearfield, UT","method":"PUT","page":"Logout","registration":1540970748796.0,"sessionId":530,"song":null,"status":307,"ts":1542676106796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"94"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":530,"song":null,"status":200,"ts":1542676109796,"userAgent":null,"userId":""} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":50,"lastName":"Graves","length":231.81016,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Use Somebody","status":200,"ts":1542676150796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Avenged Sevenfold","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":51,"lastName":"Graves","length":283.76771,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Unholy Confessions","status":200,"ts":1542676381796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"A.B. Quintanilla III Y Los Kumbia Kings","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":52,"lastName":"Graves","length":196.77995,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Te Quiero A Ti","status":200,"ts":1542676664796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Coldplay","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":53,"lastName":"Graves","length":228.62322,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Only Superstition","status":200,"ts":1542676860796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"B.o.B","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":54,"lastName":"Graves","length":269.63546,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Nothin' On You [feat. Bruno Mars] (Album Version)","status":200,"ts":1542677088796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Crystal Castles","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":55,"lastName":"Graves","length":252.89098,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Baptism","status":200,"ts":1542677357796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Justin Nozuka","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":56,"lastName":"Graves","length":213.62893,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Mr Therapy Man","status":200,"ts":1542677609796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Blackmore's Night","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":57,"lastName":"Graves","length":201.40363,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Sister Gypsy","status":200,"ts":1542677822796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":0,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":658,"song":null,"status":200,"ts":1542677846796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Beirut","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":1,"lastName":"Young","length":239.0722,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Fountains And Tramways","status":200,"ts":1542677914796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Beck","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":58,"lastName":"Graves","length":304.50893,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"End Of The Day","status":200,"ts":1542678023796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":59,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"Logout","registration":1540664184796.0,"sessionId":594,"song":null,"status":307,"ts":1542678024796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":60,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":594,"song":null,"status":200,"ts":1542678026796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":61,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":594,"song":null,"status":307,"ts":1542678027796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":62,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Home","registration":1540664184796.0,"sessionId":594,"song":null,"status":200,"ts":1542678070796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":2,"lastName":"Young","length":177.84118,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Fake Tales Of San Francisco (Explicit)","status":200,"ts":1542678153796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Van Halen","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":227.44771,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":727,"song":"Ain't Talkin' 'Bout Love (Remastered Version)","status":200,"ts":1542678180796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Settings","registration":1540621059796.0,"sessionId":727,"song":null,"status":200,"ts":1542678185796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Help","registration":1540621059796.0,"sessionId":727,"song":null,"status":200,"ts":1542678192796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Secret Garden","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":63,"lastName":"Graves","length":180.21832,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Atlantia","status":200,"ts":1542678327796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Snow Patrol","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":3,"lastName":"Young","length":274.49424,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Chasing Cars","status":200,"ts":1542678330796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Rihanna","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Burns","length":239.75138,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":727,"song":"G4L","status":200,"ts":1542678407796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Bayside","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":64,"lastName":"Graves","length":180.27057,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Duality (Album Version)","status":200,"ts":1542678507796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Todd Barry","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":4,"lastName":"Young","length":126.82404,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Sugar Ray (LP Version)","status":200,"ts":1542678604796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Bayside","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":65,"lastName":"Graves","length":243.64363,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Montauk","status":200,"ts":1542678687796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Viki Mosholiou","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":5,"lastName":"Young","length":169.84771,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Milo Gia Ta Pedia Mou (2006 Digital Remaster)","status":200,"ts":1542678730796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Hatebreed","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":6,"lastName":"Young","length":124.42077,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Worlds Apart (Album Version)","status":200,"ts":1542678899796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Sonny Boy Williamson","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":66,"lastName":"Graves","length":152.24118,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Don't Start Me Talkin'","status":200,"ts":1542678930796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Shattered Realm","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":7,"lastName":"Young","length":108.45995,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Devil In Disguise","status":200,"ts":1542679023796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Timbaland \/ Katy Perry","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":67,"lastName":"Graves","length":238.70649,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"If We Ever Meet Again","status":200,"ts":1542679082796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Sam and Dave","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":8,"lastName":"Young","length":157.28281,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Hold on I'm Coming","status":200,"ts":1542679131796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Sea Wolf","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":9,"lastName":"Young","length":225.802,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Black Dirt (Album)","status":200,"ts":1542679288796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Apocalyptica featuring Corey Taylor","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":68,"lastName":"Graves","length":214.12526,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"I'm Not Jesus","status":200,"ts":1542679320796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Bomfunk MC's","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":10,"lastName":"Young","length":225.4624,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Rocking_ Just To Make Ya Move","status":200,"ts":1542679513796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Jets To Brazil","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":69,"lastName":"Graves","length":571.03628,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Rocket Boy","status":200,"ts":1542679534796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":70,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"Logout","registration":1540664184796.0,"sessionId":594,"song":null,"status":307,"ts":1542679535796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":71,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":594,"song":null,"status":200,"ts":1542679622796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":72,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":594,"song":null,"status":307,"ts":1542679623796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":73,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Home","registration":1540664184796.0,"sessionId":594,"song":null,"status":200,"ts":1542679674796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Tavares","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":11,"lastName":"Young","length":394.00444,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Heaven Must Be Missing An Angel","status":200,"ts":1542679738796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Maria Beth\u00c3\u0083\u00c2\u00a2nia","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":74,"lastName":"Graves","length":254.06649,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Samba De Roda\/Marinheiro S\u00c3\u0083\u00c2\u00b3 (Medley) (Live)","status":200,"ts":1542680105796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":12,"lastName":"Young","length":220.89098,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Somebody To Love","status":200,"ts":1542680132796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Van Halen","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":13,"lastName":"Young","length":272.32608,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Feels So Good (Remastered Single Version)","status":200,"ts":1542680352796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Julieta Venegas A Dueto Con Dante","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":75,"lastName":"Graves","length":236.9824,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Primer Dia","status":200,"ts":1542680359796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Apocalyptica","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":76,"lastName":"Graves","length":409.86077,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Coma","status":200,"ts":1542680595796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"The Wreckers","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":14,"lastName":"Young","length":171.36281,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Stand Still_ Look Pretty [Live]","status":200,"ts":1542680624796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Prince & The Revolution","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":15,"lastName":"Young","length":227.65669,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Kiss (LP Version)","status":200,"ts":1542680795796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Third Eye Blind","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":77,"lastName":"Graves","length":319.79057,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"God Of Wine (2006 Remastered LP Version)","status":200,"ts":1542681004796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Dr. Dre \/ Eminem","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":16,"lastName":"Young","length":222.27546,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Forgot About Dre","status":200,"ts":1542681022796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Symphony X","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":17,"lastName":"Young","length":318.37995,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Evolution (the Grand Design)","status":200,"ts":1542681244796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Streetlight Manifesto","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":78,"lastName":"Graves","length":180.79302,"level":"paid","location":"Marinette, WI-MI","method":"PUT","page":"NextSong","registration":1540664184796.0,"sessionId":594,"song":"Keasbey Nights (LP Version)","status":200,"ts":1542681323796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":79,"lastName":"Graves","length":null,"level":"paid","location":"Marinette, WI-MI","method":"GET","page":"Downgrade","registration":1540664184796.0,"sessionId":594,"song":null,"status":200,"ts":1542681407796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"25"} {"artist":"Amos Lee","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":18,"lastName":"Young","length":169.16853,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Soul Suckers","status":200,"ts":1542681562796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Gabe Dixon Band","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":19,"lastName":"Young","length":296.85506,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Disappear","status":200,"ts":1542681731796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Mogwai","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":20,"lastName":"Young","length":473.25995,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Thank You Space Expert","status":200,"ts":1542682027796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Mystery Jets","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":21,"lastName":"Young","length":212.32281,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"You Can't Fool Me Dennis (Album version)","status":200,"ts":1542682500796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Mates of State","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":22,"lastName":"Young","length":227.36934,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Parachutes (Funeral Song) (LP Version)","status":200,"ts":1542682712796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":737,"song":null,"status":200,"ts":1542682800796,"userAgent":null,"userId":""} {"artist":"R.E.M.","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":23,"lastName":"Young","length":217.99138,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"Can't Get There From Here","status":200,"ts":1542682939796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":24,"lastName":"Young","length":246.282,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":658,"song":"The Best Day","status":200,"ts":1542683156796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Blockhead","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":285.98812,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":710,"song":"Carnivores Unite","status":200,"ts":1542687458796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"MC Hammer","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":256.86159,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":710,"song":"U Can't Touch This","status":200,"ts":1542687743796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Sally Shapiro","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":2,"lastName":"Hess","length":392.82893,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":710,"song":"Miracle (Extended Mix)","status":200,"ts":1542687999796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":716,"song":null,"status":307,"ts":1542694886796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":716,"song":null,"status":200,"ts":1542695016796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Holy Fuck","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Koch","length":362.762,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"P.I.G.S.","status":200,"ts":1542695032796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Angus & Julia Stone","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Koch","length":218.8273,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Soldier","status":200,"ts":1542695394796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Los Fabulosos Cadillacs","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Koch","length":275.69587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Siguiendo La Luna","status":200,"ts":1542695612796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"A Sunny Day In Glasgow","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":5,"lastName":"Koch","length":22.04689,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Lights","status":200,"ts":1542695887796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Mariah Carey Featuring Cameo","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":6,"lastName":"Koch","length":229.22404,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Loverboy","status":200,"ts":1542695909796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Tego Calderon","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":7,"lastName":"Koch","length":242.18077,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Metele Sazon","status":200,"ts":1542696138796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bloodhound Gang","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":8,"lastName":"Koch","length":172.01587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Foxtrot Uniform Charlie Kilo","status":200,"ts":1542696380796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":9,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Downgrade","registration":1541048010796.0,"sessionId":716,"song":null,"status":200,"ts":1542696434796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":10,"lastName":"Koch","length":256.36526,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"The Runner","status":200,"ts":1542696552796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Iron Maiden","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":11,"lastName":"Koch","length":233.76934,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Run To The Hills (1998 Digital Remaster)","status":200,"ts":1542696808796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Caf\u00c3\u0083\u00c2\u00a9 Tacvba","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":12,"lastName":"Koch","length":232.72444,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Mar\u00c3\u0083\u00c2\u00ada","status":200,"ts":1542697041796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Blink-182","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":13,"lastName":"Koch","length":280.00608,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"All Of This","status":200,"ts":1542697273796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Band Of Horses","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":14,"lastName":"Koch","length":321.14893,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"The Funeral (Album Version)","status":200,"ts":1542697553796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Primus","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":15,"lastName":"Koch","length":146.15465,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"De Anza Jig","status":200,"ts":1542697874796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Tom McRae","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":16,"lastName":"Koch","length":265.27302,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Walking 2 Hawaii","status":200,"ts":1542698020796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"ALO (Animal Liberation Orchestra)","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":17,"lastName":"Koch","length":229.77261,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Spectrum","status":200,"ts":1542698285796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Yelle","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":18,"lastName":"Koch","length":192.31302,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Je Veux Te Voir (Radio Edit)","status":200,"ts":1542698514796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":19,"lastName":"Koch","length":201.79546,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Revelry","status":200,"ts":1542698706796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":20,"lastName":"Koch","length":250.14812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Everlong","status":200,"ts":1542698907796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"James","gender":"M","itemInSession":0,"lastName":"Martin","length":null,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"GET","page":"Home","registration":1540810448796.0,"sessionId":701,"song":null,"status":200,"ts":1542698989796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 9.0; Windows NT 6.1; Trident\/5.0)","userId":"79"} {"artist":"Kanye West","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":21,"lastName":"Koch","length":311.84934,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Stronger","status":200,"ts":1542699157796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Annie Lennox","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":22,"lastName":"Koch","length":256.57424,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Wonderful","status":200,"ts":1542699468796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Madeleine Peyroux","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":23,"lastName":"Koch","length":214.77832,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Instead","status":200,"ts":1542699724796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Miley Cyrus","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":24,"lastName":"Koch","length":236.85179,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"The Climb","status":200,"ts":1542699938796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Coldplay","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":25,"lastName":"Koch","length":268.38159,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Yellow","status":200,"ts":1542700174796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Jag Panzer","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":26,"lastName":"Koch","length":217.99138,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Reign Of The Tyrants","status":200,"ts":1542700442796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Notorious B.I.G.","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":27,"lastName":"Koch","length":285.93587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Gimme The Loot (Album Version)","status":200,"ts":1542700659796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Emiliana Torrini","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":28,"lastName":"Koch","length":186.122,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Ha Ha (KCRW.com Presents)","status":200,"ts":1542700944796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":null,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1541032432796.0,"sessionId":735,"song":null,"status":200,"ts":1542701038796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Streetlight Manifesto","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":29,"lastName":"Koch","length":137.19465,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Punk Rock Girl","status":200,"ts":1542701130796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Dropkick Murphys","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":30,"lastName":"Koch","length":161.01832,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"The Auld Triangle (Album Version)","status":200,"ts":1542701267796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":0,"lastName":"Finley","length":null,"level":"free","location":"Richmond, VA","method":"GET","page":"Home","registration":1541013292796.0,"sessionId":473,"song":null,"status":200,"ts":1542701273796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":"Carlo Siliotto","auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":1,"lastName":"Finley","length":175.38567,"level":"free","location":"Richmond, VA","method":"PUT","page":"NextSong","registration":1541013292796.0,"sessionId":473,"song":"Kazakhstan 1710","status":200,"ts":1542701299796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":"The Raconteurs","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":31,"lastName":"Koch","length":265.50812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Top Yourself","status":200,"ts":1542701428796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Academy Is...","auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":2,"lastName":"Finley","length":207.96036,"level":"free","location":"Richmond, VA","method":"PUT","page":"NextSong","registration":1541013292796.0,"sessionId":473,"song":"We've Got A Big Mess On Our Hands (Album Edit)","status":200,"ts":1542701474796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":1,"lastName":"Owens","length":222.92853,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":735,"song":"Stuck In The Moment","status":200,"ts":1542701671796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Spiritual Beggars","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":32,"lastName":"Koch","length":358.24281,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Nowhere To Go","status":200,"ts":1542701693796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bon Iver","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":33,"lastName":"Koch","length":238.49751,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Skinny Love","status":200,"ts":1542702051796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Living End","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":34,"lastName":"Koch","length":229.0673,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Prisoner Of Society (Album Version)","status":200,"ts":1542702289796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Moby","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":35,"lastName":"Koch","length":196.75383,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Lift Me Up","status":200,"ts":1542702518796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":36,"lastName":"Koch","length":258.55955,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Cosmic Love","status":200,"ts":1542702714796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Miami Horror","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":37,"lastName":"Koch","length":386.5073,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Sometimes (Hook N Sling Remix)","status":200,"ts":1542702972796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Nacho Chapado feat. Stephen Massa","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":38,"lastName":"Koch","length":479.7122,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"B Somebody","status":200,"ts":1542703358796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Kate Nash","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":39,"lastName":"Koch","length":179.48689,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Pumpkin Soup","status":200,"ts":1542703837796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Benny Neyman","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":40,"lastName":"Koch","length":224.7571,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Waarom Fluister Ik Je Naam Nog","status":200,"ts":1542704016796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Boyzone","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":41,"lastName":"Koch","length":219.81995,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"All That I Need","status":200,"ts":1542704240796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Philip Glass","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":42,"lastName":"Koch","length":426.78812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Chinese Invade","status":200,"ts":1542704459796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Pussycat Dolls","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":43,"lastName":"Koch","length":225.61914,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Buttons","status":200,"ts":1542704885796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Madonna","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":44,"lastName":"Koch","length":260.75383,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Beautiful Stranger","status":200,"ts":1542705110796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Asking Alexandria","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":45,"lastName":"Koch","length":248.99873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Hey There Mr. Brooks (feat. Feat. Shawn Mike of Alesana)","status":200,"ts":1542705370796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Pavement","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":46,"lastName":"Koch","length":99.16036,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Mercy:The Laundromat","status":200,"ts":1542705618796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":47,"lastName":"Koch","length":236.93016,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Bubble Toes","status":200,"ts":1542705717796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Train","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":48,"lastName":"Koch","length":244.1922,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Calling All Angels","status":200,"ts":1542705953796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Cam'Ron \/ Juelz Santana","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":49,"lastName":"Koch","length":208.3522,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Oh Boy","status":200,"ts":1542706197796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Sugar Ray","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":50,"lastName":"Koch","length":218.33098,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"When It's Over (Remastered Album Version)","status":200,"ts":1542706405796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":51,"lastName":"Koch","length":209.18812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Broken-Hearted Girl","status":200,"ts":1542706623796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Faith No More","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":52,"lastName":"Koch","length":249.86077,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Last Cup Of Sorrow","status":200,"ts":1542706832796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Jokeren","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":53,"lastName":"Koch","length":239.49016,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Kvinde Din - M\u00c3\u0083\u00c2\u00b8gluder","status":200,"ts":1542707081796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Ween","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":54,"lastName":"Koch","length":250.17424,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Demon Sweat","status":200,"ts":1542707320796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"King Diamond","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":55,"lastName":"Koch","length":408.47628,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"No Presents For Christmas","status":200,"ts":1542707570796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Mint Condition","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":56,"lastName":"Koch","length":279.06567,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Somethin' (feat. Phonte from Little Brother)","status":200,"ts":1542707978796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Delorean","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":57,"lastName":"Koch","length":272.63955,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Complexity Reducer","status":200,"ts":1542708257796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Myl\u00c3\u0083\u00c2\u00a8ne Farmer","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":58,"lastName":"Koch","length":257.2273,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Porno Graphique","status":200,"ts":1542708529796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Green Day","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":59,"lastName":"Koch","length":194.06322,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Horseshoes And Handgrenades (Album Version)","status":200,"ts":1542708786796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Disturbed","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":0,"lastName":"Larson","length":185.65179,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":746,"song":"Sacred Lie (Album Version)","status":200,"ts":1542708885796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"The New Pornographers","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":60,"lastName":"Koch","length":256.41751,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Adventures In Solitude","status":200,"ts":1542708980796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Sugarcult","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":1,"lastName":"Larson","length":199.13098,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":746,"song":"Saying Goodbye","status":200,"ts":1542709070796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"Plies","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":61,"lastName":"Koch","length":231.6273,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":716,"song":"Goons Lurkin (Explicit Album Version)","status":200,"ts":1542709236796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":2,"lastName":"Larson","length":207.59465,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":746,"song":"Aerodynamic","status":200,"ts":1542709269796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":742,"song":null,"status":200,"ts":1542709455796,"userAgent":null,"userId":""} {"artist":"Train","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":216.76363,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":751,"song":"Hey_ Soul Sister","status":200,"ts":1542709870796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"The Smiths","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":0,"lastName":"Benson","length":242.9122,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":720,"song":"There Is A Light That Never Goes Out","status":200,"ts":1542711597796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"New Radicals","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":0,"lastName":"Barrett","length":300.82567,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":747,"song":"You Get What You Give","status":200,"ts":1542711660796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"The Features","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":1,"lastName":"Benson","length":125.46567,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":720,"song":"Exhibit A","status":200,"ts":1542711839796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Ella Fitzgerald","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":1,"lastName":"Barrett","length":427.15383,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":747,"song":"On Green Dolphin Street (Medley) (1999 Digital Remaster)","status":200,"ts":1542711960796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Toro Y Moi","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":2,"lastName":"Benson","length":182.02077,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":720,"song":"Causers Of This","status":200,"ts":1542711964796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"DJ Dizzy","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":3,"lastName":"Benson","length":221.1522,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":720,"song":"Sexy Bitch","status":200,"ts":1542712146796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Cartola","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":2,"lastName":"Barrett","length":127.242,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":747,"song":"Tive Sim","status":200,"ts":1542712387796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"The Casualties","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":3,"lastName":"Barrett","length":131.23873,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":747,"song":"Fight For Your Life","status":200,"ts":1542712514796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Panic! At The Disco","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":4,"lastName":"Barrett","length":186.64444,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":747,"song":"I Write Sins Not Tragedies (Album Version)","status":200,"ts":1542712645796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"The Wallflowers","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":5,"lastName":"Barrett","length":421.17179,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":747,"song":"Hollywood","status":200,"ts":1542712831796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Rick James","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":6,"lastName":"Barrett","length":295.31383,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":747,"song":"Mary Jane","status":200,"ts":1542713252796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"R\u00c3\u0083\u00c2\u00b6yksopp","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":7,"lastName":"Barrett","length":300.14649,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":747,"song":"What Else Is There?","status":200,"ts":1542713547796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Lamb","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":8,"lastName":"Barrett","length":352.20853,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":747,"song":"Gabriel","status":200,"ts":1542713847796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Joe Nichols","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":9,"lastName":"Barrett","length":237.5571,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":747,"song":"Talk Me Out Of Tampa","status":200,"ts":1542714199796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Samy Deluxe","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":0,"lastName":"Cook","length":191.16363,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":743,"song":"Pdsa","status":200,"ts":1542714413796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Sepultura","auth":"Logged In","firstName":"Harper","gender":"M","itemInSession":10,"lastName":"Barrett","length":199.23546,"level":"paid","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540685364796.0,"sessionId":747,"song":"Refuse\/Resist (Explicit Album Version)","status":200,"ts":1542714436796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"42"} {"artist":"Ozzy Osbourne","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":1,"lastName":"Cook","length":248.42404,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":743,"song":"Secret Loser","status":200,"ts":1542714604796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"VCR","auth":"Logged In","firstName":"Brayden","gender":"M","itemInSession":0,"lastName":"Clark","length":193.69751,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541029236796.0,"sessionId":736,"song":"On Its Way Out","status":200,"ts":1542715572796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"41"} {"artist":"P!nk","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":0,"lastName":"White","length":227.02975,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":697,"song":"Glitter In The Air","status":200,"ts":1542718095796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"DAVE MATTHEWS BAND","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":1,"lastName":"White","length":239.35955,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":697,"song":"Time Bomb","status":200,"ts":1542718322796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Summer Cats","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":2,"lastName":"White","length":219.42812,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":697,"song":"Wild Rice","status":200,"ts":1542718561796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":null,"auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":0,"lastName":"Johnson","length":null,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"GET","page":"Home","registration":1541081807796.0,"sessionId":713,"song":null,"status":200,"ts":1542719012796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":639,"song":null,"status":200,"ts":1542719232796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Liquid Spill","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":376.16281,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Words- Till the mornin' comes Mix","status":200,"ts":1542719242796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Ressurrection Band","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":183.17016,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"First Degree Apathy","status":200,"ts":1542719618796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Meat Loaf","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":3,"lastName":"Kirby","length":236.38159,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Because Of You","status":200,"ts":1542719801796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Josh Rouse","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":4,"lastName":"Kirby","length":258.87302,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"My Love Has Gone","status":200,"ts":1542720037796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Maddy Prior & Tim Hart","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":5,"lastName":"Kirby","length":141.37424,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Cannily Cannily","status":200,"ts":1542720295796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Bunbury","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":6,"lastName":"Kirby","length":533.78567,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Demasiado Tarde (Ahorita Mismo)","status":200,"ts":1542720436796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":7,"lastName":"Kirby","length":252.39465,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Live High (Album Version)","status":200,"ts":1542720969796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The dB's","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":8,"lastName":"Kirby","length":118.41261,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Black And White","status":200,"ts":1542721221796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Camera Obscura","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":9,"lastName":"Kirby","length":170.89261,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"The Sun On His Back","status":200,"ts":1542721339796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Juanes","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":10,"lastName":"Kirby","length":248.97261,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Para Tu Amor","status":200,"ts":1542721509796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"ATB","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":11,"lastName":"Kirby","length":262.21669,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Marrakech","status":200,"ts":1542721757796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Cracker","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":12,"lastName":"Kirby","length":205.03465,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"I'm A Little Rocket Ship","status":200,"ts":1542722019796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":766,"song":null,"status":200,"ts":1542722069796,"userAgent":null,"userId":""} {"artist":"Blue Man Group","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":13,"lastName":"Kirby","length":386.53342,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"The Complex","status":200,"ts":1542722224796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"At Vance","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":14,"lastName":"Kirby","length":201.82159,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Heart Of Steel","status":200,"ts":1542722610796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Wim Mertens","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":15,"lastName":"Kirby","length":289.88036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Houfnice","status":200,"ts":1542722811796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Beirut","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":16,"lastName":"Kirby","length":142.31465,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"The Penalty","status":200,"ts":1542723100796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Jonathan Edwards","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":17,"lastName":"Kirby","length":238.39302,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Longest Ride (LP Version )","status":200,"ts":1542723242796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Shout Out Louds","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":18,"lastName":"Kirby","length":215.97995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"There's Nothing","status":200,"ts":1542723480796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":0,"lastName":"Summers","length":null,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"GET","page":"Home","registration":1540344794796.0,"sessionId":705,"song":null,"status":200,"ts":1542723485796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"John Mayer","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":1,"lastName":"Summers","length":255.11138,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":705,"song":"War Of My Life","status":200,"ts":1542723488796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Los Campesinos!","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":19,"lastName":"Kirby","length":119.11791,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"(PLAN A)","status":200,"ts":1542723695796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Scissor Sisters","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":20,"lastName":"Kirby","length":271.85587,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Take Your Mama","status":200,"ts":1542723814796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kid Cudi Vs Crookers","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":21,"lastName":"Kirby","length":162.97751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Day 'N' Nite","status":200,"ts":1542724085796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Ana Torroja","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":22,"lastName":"Kirby","length":311.66649,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Un A\u00c3\u0083\u00c2\u00b1o Mas","status":200,"ts":1542724247796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":23,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":639,"song":null,"status":200,"ts":1542724256796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"John Mayer","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":24,"lastName":"Kirby","length":250.38322,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Half Of My Heart","status":200,"ts":1542724558796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Lyle Mays","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":0,"lastName":"Young","length":240.97914,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":759,"song":"This Moment (Album Version)","status":200,"ts":1542724720796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Beenie Man","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":25,"lastName":"Kirby","length":230.03383,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Girls Dem Sugar","status":200,"ts":1542724808796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The-Dream \/ Fabolous","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":1,"lastName":"Young","length":262.81751,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":759,"song":"Shawty Is Da Sh*!","status":200,"ts":1542724960796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Soul II Soul","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":26,"lastName":"Kirby","length":239.67302,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"How Long","status":200,"ts":1542725038796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Arcade Fire","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":2,"lastName":"Young","length":169.19465,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":759,"song":"I'm Sleeping In A Submarine","status":200,"ts":1542725222796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Kansas","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":27,"lastName":"Kirby","length":233.03791,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Hold On","status":200,"ts":1542725277796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Snow Patrol","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":3,"lastName":"Young","length":223.18975,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":759,"song":"Set Down Your Glass","status":200,"ts":1542725391796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":28,"lastName":"Kirby","length":224.9922,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Forever & Always","status":200,"ts":1542725510796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kylie Minogue","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":4,"lastName":"Young","length":271.3073,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":759,"song":"Come Into My World","status":200,"ts":1542725614796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Paulina Rubio","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":29,"lastName":"Kirby","length":174.31465,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Un Dia Gris","status":200,"ts":1542725734796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Andrew Bird","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":5,"lastName":"Young","length":252.31628,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":759,"song":"Fiery Crash","status":200,"ts":1542725885796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Rapture","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":30,"lastName":"Kirby","length":323.47383,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Open Up Your Heart","status":200,"ts":1542725908796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Horkyze Slyze","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":6,"lastName":"Young","length":124.44689,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":759,"song":"Fakty","status":200,"ts":1542726137796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Killers","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":31,"lastName":"Kirby","length":220.89098,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"When You Were Young","status":200,"ts":1542726231796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":7,"lastName":"Young","length":252.39465,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":759,"song":"Live High (Album Version)","status":200,"ts":1542726261796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Lady GaGa","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":32,"lastName":"Kirby","length":263.33995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Paper Gangsta","status":200,"ts":1542726451796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Hans Zimmer_ James Newton Howard","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":8,"lastName":"Young","length":265.50812,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":759,"song":"Nycteris","status":200,"ts":1542726513796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Soltero","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":33,"lastName":"Kirby","length":191.7122,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Step Through The Door","status":200,"ts":1542726714796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Blur","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":34,"lastName":"Kirby","length":237.03465,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Country House","status":200,"ts":1542726905796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Carlton Livingston_ Shabba Ranks","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":35,"lastName":"Kirby","length":226.32444,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Rumours","status":200,"ts":1542727142796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Finger Eleven","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":36,"lastName":"Kirby","length":208.1171,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Paralyzer","status":200,"ts":1542727368796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Elbee Bad","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":37,"lastName":"Kirby","length":254.53669,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Dream On! New Age Of Faith \/ Smokebelch","status":200,"ts":1542727576796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Boney James","auth":"Logged In","firstName":"Molly","gender":"F","itemInSession":0,"lastName":"Taylor","length":327.3922,"level":"free","location":"St. Louis, MO-IL","method":"PUT","page":"NextSong","registration":1540992766796.0,"sessionId":740,"song":"Seduction (Album Version)","status":200,"ts":1542727613796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"35"} {"artist":"Sauce Money Featuring Memphis Bleek","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":38,"lastName":"Kirby","length":280.21506,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"What We Do (Explicit) (Feat. Memphis Bleek)","status":200,"ts":1542727830796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Toy Matinee","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":39,"lastName":"Kirby","length":297.19465,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Things She Said","status":200,"ts":1542728110796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Markus Kruneg\u00c3\u0083\u00c2\u00a5rd","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":40,"lastName":"Kirby","length":256.93995,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Jag \u00c3\u0083\u00c2\u00a4r en vampyr","status":200,"ts":1542728407796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":0,"lastName":"Barrera","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540835983796.0,"sessionId":595,"song":null,"status":200,"ts":1542728456796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"The Mountain Goats","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":41,"lastName":"Kirby","length":222.74567,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Heretic Pride","status":200,"ts":1542728663796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Sienna","gender":"F","itemInSession":0,"lastName":"Colon","length":209.52771,"level":"free","location":"Las Cruces, NM","method":"PUT","page":"NextSong","registration":1540013692796.0,"sessionId":386,"song":"Float On","status":200,"ts":1542728683796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"81"} {"artist":"Emiliana Torrini","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":42,"lastName":"Kirby","length":184.29342,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Sunny Road","status":200,"ts":1542728885796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Habib Koit\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Sienna","gender":"F","itemInSession":1,"lastName":"Colon","length":305.71057,"level":"free","location":"Las Cruces, NM","method":"PUT","page":"NextSong","registration":1540013692796.0,"sessionId":386,"song":"Baro","status":200,"ts":1542728892796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"81"} {"artist":"Lonnie Gordon","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":1,"lastName":"Barrera","length":181.21098,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":595,"song":"Catch You Baby (Steve Pitron & Max Sanna Radio Edit)","status":200,"ts":1542729001796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Busdriver","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":43,"lastName":"Kirby","length":202.16118,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"The Troglodyte Wins","status":200,"ts":1542729069796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"SOJA","auth":"Logged In","firstName":"Sienna","gender":"F","itemInSession":2,"lastName":"Colon","length":285.25669,"level":"free","location":"Las Cruces, NM","method":"PUT","page":"NextSong","registration":1540013692796.0,"sessionId":386,"song":"Rasta Courage","status":200,"ts":1542729197796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"81"} {"artist":"Mike And The Mechanics","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":44,"lastName":"Kirby","length":275.12118,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"A Beggar On A Beach Of Gold","status":200,"ts":1542729271796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Evanescence","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":45,"lastName":"Kirby","length":224.10404,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Lithium","status":200,"ts":1542729546796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":46,"lastName":"Kirby","length":229.0673,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"One Less Lonely Girl","status":200,"ts":1542729770796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Brandon Heath","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":47,"lastName":"Kirby","length":232.69832,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Give Me Your Eyes","status":200,"ts":1542729999796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":48,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Settings","registration":1541022995796.0,"sessionId":639,"song":null,"status":200,"ts":1542730023796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":49,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"Save Settings","registration":1541022995796.0,"sessionId":639,"song":null,"status":307,"ts":1542730024796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":50,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":639,"song":null,"status":200,"ts":1542730040796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Samael","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":221.33506,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":756,"song":"Under One Flag","status":200,"ts":1542730076796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Steve Bug","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":51,"lastName":"Kirby","length":438.67383,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Smackman","status":200,"ts":1542730231796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":52,"lastName":"Kirby","length":208.48281,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Down On The Farm","status":200,"ts":1542730669796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"New Boyz","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":53,"lastName":"Kirby","length":178.80771,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Tie Me Down [feat. Ray J] (Amended Album Version)","status":200,"ts":1542730877796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Train","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":54,"lastName":"Kirby","length":216.76363,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Hey_ Soul Sister","status":200,"ts":1542731055796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":758,"song":null,"status":307,"ts":1542731084796,"userAgent":null,"userId":""} {"artist":"Randy Crawford","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":55,"lastName":"Kirby","length":270.75873,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":639,"song":"Almaz","status":200,"ts":1542731271796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Cro-Mags","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":0,"lastName":"Rogers","length":206.99383,"level":"free","location":"San Diego-Carlsbad, CA","method":"PUT","page":"NextSong","registration":1540976199796.0,"sessionId":459,"song":"Eyes Of Tomorrow","status":200,"ts":1542731897796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_2) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"18"} {"artist":"Animal Collective","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":322.0371,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":767,"song":"In The Flowers","status":200,"ts":1542732730796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":767,"song":null,"status":200,"ts":1542733080796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":758,"song":null,"status":200,"ts":1542733125796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Marisa Monte","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":290.95138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"O Xote Das Meninas\/Asa Branca\/Hino A Sao Jose","status":200,"ts":1542734311796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Hollywood Undead","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":210.52036,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Everywhere I Go","status":200,"ts":1542734601796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jos\u00c3\u0083\u00c2\u00a9 Gonz\u00c3\u0083\u00c2\u00a1lez","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":162.97751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Crosses","status":200,"ts":1542734811796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Tom Petty And The Heartbreakers","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":241.52771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Learning To Fly","status":200,"ts":1542734973796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sara Bareilles","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":233.37751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Gravity","status":200,"ts":1542735214796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":0,"lastName":"Garrison","length":null,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"GET","page":"Home","registration":1540832693796.0,"sessionId":730,"song":null,"status":200,"ts":1542735267796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":"Asian Dub Foundation","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":264.69832,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Rise To The Challenge","status":200,"ts":1542735447796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cast Of Camp Rock","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":190.71955,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":729,"song":"We Rock","status":200,"ts":1542735591796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"The Killers","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":287.73832,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"All The Pretty Faces","status":200,"ts":1542735711796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Yung Berg feat. Young Jeezy & Ludacris","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":1,"lastName":"Johnson","length":177.162,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":729,"song":"285 (feat. Young Jeezy & Ludacris)","status":200,"ts":1542735781796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"Sin Bandera","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":2,"lastName":"Johnson","length":252.78649,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":729,"song":"Si Me Besas","status":200,"ts":1542735958796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":229.61587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Let's Get It Started","status":200,"ts":1542735998796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":3,"lastName":"Johnson","length":208.14322,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":729,"song":"Apologize","status":200,"ts":1542736210796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"Charlie Louvin","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":170.86649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"I Think I'll Live","status":200,"ts":1542736227796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ill Nino","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":202.57914,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Unframed (Album Version)","status":200,"ts":1542736397796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Coldplay","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":294.1122,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Fix You","status":200,"ts":1542736599796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kansas","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":275.9571,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Carry On Wayward Son","status":200,"ts":1542736893796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":780,"song":null,"status":200,"ts":1542736908796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Kurtis Blow","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":0,"lastName":"Santana","length":353.88036,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":722,"song":"The Breaks","status":200,"ts":1542737063796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Chromeo","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":171.57179,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":717,"song":"Momma's Boy","status":200,"ts":1542737077796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Beach House","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":322.71628,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Walk In The Park","status":200,"ts":1542737168796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":236.35546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Ego","status":200,"ts":1542737490796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kid Cudi \/ MGMT \/ Ratatat","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":295.67955,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Pursuit Of Happiness (nightmare)","status":200,"ts":1542737726796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Erin McKeown","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":17,"lastName":"Cuevas","length":292.75383,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Daisy And Prudence","status":200,"ts":1542738021796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Andres Calamaro","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":18,"lastName":"Cuevas","length":263.83628,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Los Aviones","status":200,"ts":1542738313796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Akon","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":19,"lastName":"Cuevas","length":253.77914,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Freedom","status":200,"ts":1542738576796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Los Bunkers","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":20,"lastName":"Cuevas","length":217.83465,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Ven Aqu\u00c3\u0083\u00c2\u00ad","status":200,"ts":1542738829796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Steely Dan","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":21,"lastName":"Cuevas","length":273.94567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Reelin' In The Years","status":200,"ts":1542739046796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Aterciopelados","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":22,"lastName":"Cuevas","length":169.45587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Complemento","status":200,"ts":1542739319796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":23,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Settings","registration":1540940782796.0,"sessionId":758,"song":null,"status":200,"ts":1542739447796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":24,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"Save Settings","registration":1540940782796.0,"sessionId":758,"song":null,"status":307,"ts":1542739448796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":25,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":758,"song":null,"status":200,"ts":1542740365796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Avett Brothers","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":26,"lastName":"Cuevas","length":291.36934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Laundry Room","status":200,"ts":1542740755796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Metallica","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":27,"lastName":"Cuevas","length":284.86485,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Fight Fire With Fire","status":200,"ts":1542741046796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Rihanna","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":28,"lastName":"Cuevas","length":208.40444,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Te Amo","status":200,"ts":1542741330796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":783,"song":null,"status":200,"ts":1542741428796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Sepultura","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":29,"lastName":"Cuevas","length":238.62812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"More Of The Same","status":200,"ts":1542741538796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Fate","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":290.58567,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":783,"song":"(I Can't Stand) Losing You (2004 Digital Remaster)","status":200,"ts":1542741570796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Stone Temple Pilots","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":30,"lastName":"Cuevas","length":155.24526,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Days Of The Week (Album Version)","status":200,"ts":1542741776796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sean Kingston and Justin Bieber","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":201.9522,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":783,"song":"Eenie Meenie","status":200,"ts":1542741860796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Iron Maiden","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":31,"lastName":"Cuevas","length":233.76934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Run To The Hills (1998 Digital Remaster)","status":200,"ts":1542741931796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Blackalicious","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":32,"lastName":"Cuevas","length":206.36689,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Make You Feel That Way","status":200,"ts":1542742164796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":0,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":776,"song":null,"status":200,"ts":1542742247796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":1,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Settings","registration":1540465241796.0,"sessionId":776,"song":null,"status":200,"ts":1542742282796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Deftones","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":2,"lastName":"Young","length":372.97587,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Head Up (LP Version)","status":200,"ts":1542742287796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Destiny's Child","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":33,"lastName":"Cuevas","length":271.33342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Say My Name","status":200,"ts":1542742370796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":34,"lastName":"Cuevas","length":167.6273,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"If You Want To Sing Out_ Sing Out","status":200,"ts":1542742641796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Notorious B.I.G.","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":3,"lastName":"Young","length":239.75138,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Playa Hater (Amended Version)","status":200,"ts":1542742659796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Eminem \/ Dr. Dre \/ 50 Cent","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":35,"lastName":"Cuevas","length":297.482,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Crack A Bottle","status":200,"ts":1542742808796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":733,"song":null,"status":200,"ts":1542742881796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Orchestral Manoeuvres In The Dark","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":4,"lastName":"Young","length":263.26159,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Stay (The Black Rose And The Universal Wheel)","status":200,"ts":1542742898796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Settings","registration":1541033612796.0,"sessionId":733,"song":null,"status":200,"ts":1542742933796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":733,"song":null,"status":200,"ts":1542743003796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Vangelis","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":5,"lastName":"Young","length":280.21506,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Roxane's Veil","status":200,"ts":1542743161796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":36,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":758,"song":null,"status":200,"ts":1542743348796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Spandau Ballet","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":6,"lastName":"Young","length":333.63546,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"True","status":200,"ts":1542743441796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":7,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Help","registration":1540465241796.0,"sessionId":776,"song":null,"status":200,"ts":1542743450796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Pussycat Dolls","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":8,"lastName":"Young","length":197.90322,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"I'm Done","status":200,"ts":1542743774796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Hollies","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":9,"lastName":"Young","length":252.96934,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"I'm Down","status":200,"ts":1542743971796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":10,"lastName":"Young","length":190.95465,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"LDN","status":200,"ts":1542744223796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Fall Out Boy","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":11,"lastName":"Young","length":231.47057,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"She's My Winona","status":200,"ts":1542744413796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Home","registration":1541044398796.0,"sessionId":731,"song":null,"status":200,"ts":1542744544796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Metallica","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":12,"lastName":"Young","length":396.40771,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"The Unforgiven II","status":200,"ts":1542744644796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Journey","auth":"Logged In","firstName":"Hannah","gender":"F","itemInSession":0,"lastName":"Calhoun","length":244.06159,"level":"free","location":"Los Angeles-Long Beach-Anaheim, CA","method":"PUT","page":"NextSong","registration":1540583221796.0,"sessionId":410,"song":"Loved By You","status":200,"ts":1542744929796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_1 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D201 Safari\/9537.53\"","userId":"64"} {"artist":"O-Zone","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":13,"lastName":"Young","length":213.7073,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Dragostea din tin (ma-ya-hi)","status":200,"ts":1542745040796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Spinners","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":37,"lastName":"Cuevas","length":187.27138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"It's A Shame","status":200,"ts":1542745164796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Murs","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":14,"lastName":"Young","length":256.7571,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Bad Man!","status":200,"ts":1542745253796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Navajita Platea","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":38,"lastName":"Cuevas","length":261.14567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Desde Mi Azotea (Version JDK)","status":200,"ts":1542745351796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Basshunter","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":15,"lastName":"Young","length":207.0722,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Boten Anna [Radio edit]","status":200,"ts":1542745509796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Melody Gardot","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":39,"lastName":"Cuevas","length":322.97751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Some Lessons","status":200,"ts":1542745612796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Maelo Ruiz","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":16,"lastName":"Young","length":292.77995,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Te Va A Doler","status":200,"ts":1542745716796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Aaliyah","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":40,"lastName":"Cuevas","length":289.88036,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"At Your Best You Are Love","status":200,"ts":1542745934796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":17,"lastName":"Young","length":239.3073,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"You're The One","status":200,"ts":1542746008796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Coldplay","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":41,"lastName":"Cuevas","length":307.51302,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Clocks","status":200,"ts":1542746223796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Fragma","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":18,"lastName":"Young","length":440.76363,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Everytime You Need Me (Pulsedriver Remix) (Instrumental)","status":200,"ts":1542746247796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Rihanna","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":42,"lastName":"Cuevas","length":268.25098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Don't Stop The Music","status":200,"ts":1542746530796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Temple Of The Dog","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":19,"lastName":"Young","length":243.9571,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Hunger Strike","status":200,"ts":1542746687796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Tears For Fears","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":43,"lastName":"Cuevas","length":255.34649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Head Over Heels","status":200,"ts":1542746798796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Base Ball Bear","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":20,"lastName":"Young","length":255.60771,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Sayonara-Nostalgia","status":200,"ts":1542746930796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Train","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":44,"lastName":"Cuevas","length":234.50077,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Skyscraper","status":200,"ts":1542747053796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Rufus Wainwright","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":21,"lastName":"Young","length":249.62567,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Hallelujah","status":200,"ts":1542747185796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Confederate Railroad","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":45,"lastName":"Cuevas","length":202.57914,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Jesus And Mama (LP Version)","status":200,"ts":1542747287796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Leona Lewis","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":22,"lastName":"Young","length":203.88526,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Forgive Me","status":200,"ts":1542747434796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":23,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Settings","registration":1540465241796.0,"sessionId":776,"song":null,"status":200,"ts":1542747445796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":24,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"Save Settings","registration":1540465241796.0,"sessionId":776,"song":null,"status":307,"ts":1542747446796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Panic At The Disco","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":46,"lastName":"Cuevas","length":259.29098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Behind The Sea [Live In Chicago]","status":200,"ts":1542747489796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":25,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":776,"song":null,"status":200,"ts":1542747505796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Jesse Cook","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":26,"lastName":"Young","length":240.43057,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Byzantium Underground","status":200,"ts":1542747637796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":47,"lastName":"Cuevas","length":221.20444,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Feel Good Inc (Album Version)","status":200,"ts":1542747748796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":27,"lastName":"Young","length":277.15873,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1542747877796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Paramore","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":48,"lastName":"Cuevas","length":267.65016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"The Only Exception (Album Version)","status":200,"ts":1542747969796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Yonder Mountain String Band","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":28,"lastName":"Young","length":297.58649,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Boatman's Dance","status":200,"ts":1542748154796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":49,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Downgrade","registration":1540940782796.0,"sessionId":758,"song":null,"status":200,"ts":1542748331796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Nine Inch Nails","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":29,"lastName":"Young","length":293.69424,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Dead Souls (LP Version)","status":200,"ts":1542748451796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Robert Calvert","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":30,"lastName":"Young","length":140.61669,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"The Making Of Midgard (2007 Digital Remaster)","status":200,"ts":1542748744796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Abydos","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":31,"lastName":"Young","length":76.85179,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Green's Guidance For A Stategy Adventure Game","status":200,"ts":1542748884796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Karsh Kale","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":32,"lastName":"Young","length":446.27546,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Break of Dawn","status":200,"ts":1542748960796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Machine Head","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":33,"lastName":"Young","length":542.58893,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Halo (Explicit Album Version)","status":200,"ts":1542749406796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Orishas","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":50,"lastName":"Cuevas","length":247.43138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Quien Te Dijo","status":200,"ts":1542749831796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Common \/ Vinia Mojica \/ Roy Hargrove \/ Femi Kuti","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":34,"lastName":"Young","length":356.07465,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"Time Traveling (A Tribute To Fela)","status":200,"ts":1542749948796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Ricardo Montaner","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":51,"lastName":"Cuevas","length":249.41669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Y Como Es El","status":200,"ts":1542750078796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Denise Jannah","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":35,"lastName":"Young","length":477.04771,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":776,"song":"'Round Midnight","status":200,"ts":1542750304796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":36,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"About","registration":1540465241796.0,"sessionId":776,"song":null,"status":200,"ts":1542750314796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Loudon Wainwright III","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":52,"lastName":"Cuevas","length":147.74812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"I Suppose","status":200,"ts":1542750327796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Seeed","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":53,"lastName":"Cuevas","length":192.80934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Ding (Thing Feat. Saian Supa Crew)","status":200,"ts":1542750474796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Yung Berg","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":54,"lastName":"Cuevas","length":230.63465,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Do That There (featuring Dude 'N Nem)","status":200,"ts":1542750666796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"My Chemical Romance","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":184.71138,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":789,"song":"I'm Not Okay (I Promise) (Live From Sessions@AOL)","status":200,"ts":1542750718796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Country Joe & The Fish","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":55,"lastName":"Cuevas","length":294.76526,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Rockin Round The World","status":200,"ts":1542750896796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":208.92689,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":789,"song":"What I've Done (Album Version)","status":200,"ts":1542750902796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Emiliana Torrini","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":56,"lastName":"Cuevas","length":257.67138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Me And Armini","status":200,"ts":1542751190796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Viola","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":57,"lastName":"Cuevas","length":260.25751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Nostalgia Amnesia","status":200,"ts":1542751447796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Panic At The Disco","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":58,"lastName":"Cuevas","length":114.31138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Folkin' Around [Live In Chicago]","status":200,"ts":1542751707796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Travis","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":59,"lastName":"Cuevas","length":204.7473,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Good Feeling","status":200,"ts":1542751821796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":60,"lastName":"Cuevas","length":201.79546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"Revelry","status":200,"ts":1542752025796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Darkness","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":61,"lastName":"Cuevas","length":206.81098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"One Way Ticket [Radio Edit]","status":200,"ts":1542752226796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":62,"lastName":"Cuevas","length":168.64608,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":758,"song":"You've Got The Love","status":200,"ts":1542752432796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":63,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"Logout","registration":1540940782796.0,"sessionId":758,"song":null,"status":307,"ts":1542752433796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":64,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":758,"song":null,"status":200,"ts":1542752925796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":65,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"About","registration":null,"sessionId":758,"song":null,"status":200,"ts":1542753436796,"userAgent":null,"userId":""}
460.720317
585
0.697573
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":741,"song":null,"status":307,"ts":1542760054796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Smith","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540306145796.0,"sessionId":741,"song":null,"status":200,"ts":1542760086796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":774,"song":null,"status":200,"ts":1542761399796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":774,"song":null,"status":200,"ts":1542761485796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":774,"song":null,"status":307,"ts":1542761486796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":774,"song":null,"status":200,"ts":1542761784796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Facto Delafe y las flores azules","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":315.81995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Enero en la playa","status":200,"ts":1542761878796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":204.2771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Manhattan","status":200,"ts":1542761921796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Franz Ferdinand","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":204.12036,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Michael","status":200,"ts":1542762125796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Blue October","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":272.32608,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Drilled A Wire Through My Cheek","status":200,"ts":1542762193796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"Logout","registration":1540794356796.0,"sessionId":774,"song":null,"status":307,"ts":1542762194796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Elisa","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":248.97261,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Almeno Tu Nell'Universo","status":200,"ts":1542762329796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":7,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":774,"song":null,"status":200,"ts":1542762436796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":8,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":774,"song":null,"status":307,"ts":1542762437796,"userAgent":null,"userId":""} {"artist":"The Killers","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":225.12281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"A Dustland Fairytale","status":200,"ts":1542762577796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Fran\u00c3\u0083\u00c2\u00a7oise Hardy","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":210.12853,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Noir Sur Blanc","status":200,"ts":1542762802796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Air","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":212.21832,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Playground Love","status":200,"ts":1542763012796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Ferry Corsten","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":219.55873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Punk (Radio Edit)","status":200,"ts":1542763224796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":211.722,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Unite (2009 Digital Remaster)","status":200,"ts":1542763443796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Henryk Gorecki","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":1029.642,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Symphony No. 3: III. Lento - Cantablile Semplice","status":200,"ts":1542763654796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":774,"song":null,"status":200,"ts":1542764573796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jill Scott","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":213.39383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Gimme","status":200,"ts":1542764627796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Fleet Foxes","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":253.04771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Drops In The River","status":200,"ts":1542764683796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Wallflowers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":389.95546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Another One In The Dark","status":200,"ts":1542764840796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Orishas","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":242.85995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Atrevido","status":200,"ts":1542764936796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Coyote Shivers","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":335.15057,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"You're Mine","status":200,"ts":1542765178796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Adoniran Barbosa","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":225.74975,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Fica Mais Um Pouco Amor","status":200,"ts":1542765229796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Traveling Wilburys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":207.59465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"End Of The Line","status":200,"ts":1542765454796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"ISRAEL & NEW BREED","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":12,"lastName":"Harrell","length":191.76444,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Favor Of The Lord","status":200,"ts":1542765513796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Selena","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":235.88526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Ya No","status":200,"ts":1542765661796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Sunbeam","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":13,"lastName":"Harrell","length":383.21587,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"One Minute In Heaven","status":200,"ts":1542765704796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Guru Josh Project","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":192.15628,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Infinity 2008","status":200,"ts":1542765896796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Modeselektor","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":14,"lastName":"Harrell","length":290.40281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Hasir","status":200,"ts":1542766087796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Emma Bunton","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":241.05751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"What Took You So Long","status":200,"ts":1542766088796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":239.22893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Move Along","status":200,"ts":1542766329796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":15,"lastName":"Harrell","length":201.79546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Revelry","status":200,"ts":1542766377796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Megadeth","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":18,"lastName":"Levine","length":152.65914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Paranoid","status":200,"ts":1542766568796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":16,"lastName":"Harrell","length":291.60444,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":671,"song":"Speed Of Sound","status":200,"ts":1542766578796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":17,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Downgrade","registration":1540472624796.0,"sessionId":671,"song":null,"status":200,"ts":1542766683796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Harmonia","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":19,"lastName":"Levine","length":655.77751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Sehr kosmisch","status":200,"ts":1542766720796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":0,"lastName":"Garrison","length":null,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"GET","page":"Home","registration":1540832693796.0,"sessionId":784,"song":null,"status":200,"ts":1542767304796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":"Eyehategod","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":20,"lastName":"Levine","length":310.85669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Anxiety Hangover","status":200,"ts":1542767375796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Entre R\u00c3\u0083\u00c2\u00ados","auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":1,"lastName":"Garrison","length":281.15546,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"PUT","page":"NextSong","registration":1540832693796.0,"sessionId":784,"song":"Hoy No","status":200,"ts":1542767466796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":"Rammstein","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":21,"lastName":"Levine","length":289.2273,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Du Riechst So Gut","status":200,"ts":1542767685796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Delerium","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":22,"lastName":"Levine","length":455.8624,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Drama","status":200,"ts":1542767974796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":23,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"Logout","registration":1540794356796.0,"sessionId":774,"song":null,"status":307,"ts":1542767975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":24,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":774,"song":null,"status":200,"ts":1542768002796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":25,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":774,"song":null,"status":307,"ts":1542768003796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":26,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":774,"song":null,"status":200,"ts":1542768175796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Gareth Emery","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":27,"lastName":"Levine","length":478.92853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"More Than Everything","status":200,"ts":1542768429796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Tevin Campbell","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":28,"lastName":"Levine","length":286.69342,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"I'm Ready (Album Version)","status":200,"ts":1542768907796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Hector Lavoe","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":29,"lastName":"Levine","length":330.70975,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Hacha Y Machete","status":200,"ts":1542769193796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":30,"lastName":"Levine","length":195.94404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Sincerit\u00c3\u0083\u00c2\u00a9 Et Jalousie","status":200,"ts":1542769523796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":31,"lastName":"Levine","length":224.67873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Secrets","status":200,"ts":1542769718796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Marea","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":32,"lastName":"Levine","length":261.90322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Marea (version acustica)","status":200,"ts":1542769942796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mutemath","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":33,"lastName":"Levine","length":72.95955,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Collapse (Album Version)","status":200,"ts":1542770203796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Yeasayer","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":34,"lastName":"Levine","length":241.89342,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Ambling Alp (DJ \/Rupture & Brent Arnold Remix)","status":200,"ts":1542770275796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Righteous Brothers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":35,"lastName":"Levine","length":225.27955,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"You've Lost That Lovin' Feelin'","status":200,"ts":1542770516796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Katy Perry","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":36,"lastName":"Levine","length":179.40853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"I Kissed A Girl","status":200,"ts":1542770741796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Crests","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":37,"lastName":"Levine","length":182.88281,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"16 Candles","status":200,"ts":1542770920796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Anberlin","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":38,"lastName":"Levine","length":215.24853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Breathe","status":200,"ts":1542771102796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":296.80281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"What If","status":200,"ts":1542771267796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Johnnie Taylor","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":39,"lastName":"Levine","length":269.06077,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Disco Lady","status":200,"ts":1542771317796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Xavier Rudd","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":180.61016,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"My Missing","status":200,"ts":1542771563796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Richard Holmes","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":40,"lastName":"Levine","length":213.99465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":774,"song":"Flyjack","status":200,"ts":1542771586796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":41,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"Logout","registration":1540794356796.0,"sessionId":774,"song":null,"status":307,"ts":1542771587796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Telex","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":205.63546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Spike Jones","status":200,"ts":1542771743796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Jimi Hendrix","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":393.19465,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Here He Comes (Lover Man)","status":200,"ts":1542771948796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":42,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":774,"song":null,"status":200,"ts":1542772272796,"userAgent":null,"userId":""} {"artist":"Manu Katch\u00c3\u0083\u00c2\u00a9_ Mathias Eick_ Trygve Seim_ Marcin Wasilewski_ Slawomir Kurkiewicz","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":298.78812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Snapshot","status":200,"ts":1542772341796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"John Michael Talbot","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":210.49424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Holy Is His Name (For The Bride Album Version)","status":200,"ts":1542772639796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"John Legend","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":278.77832,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"P.D.A. (We Just Don't Care)","status":200,"ts":1542772849796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Mike Shiver","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":400.29995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"On The Surface","status":200,"ts":1542773127796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Eminem \/ Dina Rae","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":350.11873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Superman","status":200,"ts":1542773527796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":151.562,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Me & Mr Jones","status":200,"ts":1542773877796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Downgrade","registration":1540472624796.0,"sessionId":797,"song":null,"status":200,"ts":1542773905796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Duncan Dhu","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":202.91873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"No Puedo Evitar (Pensar En Ti)","status":200,"ts":1542774028796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Sneaker Pimps","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":12,"lastName":"Harrell","length":250.67057,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Lightning Field","status":200,"ts":1542774230796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Trey Songz","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":13,"lastName":"Harrell","length":246.90893,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"LOL :-) [feat. Gucci Mane & Soulja Boy Tell 'Em] (Album Version)","status":200,"ts":1542774480796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"C\u00c3\u0083\u00c2\u00b3mplices","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":14,"lastName":"Harrell","length":270.602,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Es Por Ti","status":200,"ts":1542774726796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":15,"lastName":"Harrell","length":201.06404,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Our Song","status":200,"ts":1542774996796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Amos Lee","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":16,"lastName":"Harrell","length":190.87628,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Kid","status":200,"ts":1542775197796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Dead Kennedys","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":17,"lastName":"Harrell","length":188.42077,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Kill The Poor","status":200,"ts":1542775387796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Caf\u00c3\u0083\u00c2\u00a9 Tacvba","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":18,"lastName":"Harrell","length":174.41914,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"El cicl\u00c3\u0083\u00c2\u00b3n","status":200,"ts":1542775575796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Thousand Foot Krutch","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":19,"lastName":"Harrell","length":208.74404,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Move","status":200,"ts":1542775749796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"SOJA","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":20,"lastName":"Harrell","length":265.87383,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Look within","status":200,"ts":1542775957796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":21,"lastName":"Harrell","length":201.79546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Revelry","status":200,"ts":1542776222796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":22,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Settings","registration":1540472624796.0,"sessionId":797,"song":null,"status":200,"ts":1542776247796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":23,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Help","registration":1540472624796.0,"sessionId":797,"song":null,"status":200,"ts":1542776289796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Red Jumpsuit Apparatus","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":0,"lastName":"Davidson","length":191.84281,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"Face Down (Album Version)","status":200,"ts":1542776316796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Panic At The Disco","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":24,"lastName":"Harrell","length":259.29098,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Behind The Sea [Live In Chicago]","status":200,"ts":1542776423796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Pavement","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":1,"lastName":"Davidson","length":99.16036,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"Mercy:The Laundromat","status":200,"ts":1542776507796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Lucinda Williams","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":2,"lastName":"Davidson","length":254.79791,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"Fancy Funeral","status":200,"ts":1542776606796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Alfredo Zitarrosa","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":25,"lastName":"Harrell","length":267.02322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Milonga En Do","status":200,"ts":1542776682796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"First Aid Kit","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":3,"lastName":"Davidson","length":187.97669,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"Tangerine","status":200,"ts":1542776860796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Sam Cooke","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":26,"lastName":"Harrell","length":122.04363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Ain't Misbehavin","status":200,"ts":1542776949796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Thursday","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":4,"lastName":"Davidson","length":235.62404,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"Autobiography Of A Nation (Album Version)","status":200,"ts":1542777047796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":27,"lastName":"Harrell","length":184.0322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Live And Let Die","status":200,"ts":1542777071796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Enigma","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":262.71302,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":794,"song":"Knocking On Forbidden Doors","status":200,"ts":1542777221796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Dread Zeppelin","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":28,"lastName":"Harrell","length":217.49506,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Dancin' On The Killing Floor","status":200,"ts":1542777255796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Sister Hazel","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":5,"lastName":"Davidson","length":220.47302,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"Happy","status":200,"ts":1542777282796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":29,"lastName":"Harrell","length":233.27302,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Swing_ Swing","status":200,"ts":1542777472796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Evanescence","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":237.11302,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":794,"song":"Bring Me To Life","status":200,"ts":1542777483796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":6,"lastName":"Davidson","length":256.522,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"Hello","status":200,"ts":1542777502796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Tycho","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":30,"lastName":"Harrell","length":251.27138,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"The Daydream","status":200,"ts":1542777705796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"No Te Va Gustar","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":7,"lastName":"Davidson","length":35.86567,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"A La villa","status":200,"ts":1542777758796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Twista feat. Kayne West & Jamie Foxx","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":8,"lastName":"Davidson","length":212.55791,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"Slow Jamz (Feat. Kanye West & Jamie Foxx) (Edited Album Version)","status":200,"ts":1542777793796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Incubus","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":31,"lastName":"Harrell","length":263.60118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Are You In?","status":200,"ts":1542777956796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Cold","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":9,"lastName":"Davidson","length":189.83138,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"Stupid Girl","status":200,"ts":1542778005796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Wu-Tang Clan","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":10,"lastName":"Davidson","length":214.85669,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"Dog Sh*t","status":200,"ts":1542778194796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Cyndi Lauper","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":32,"lastName":"Harrell","length":228.88444,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Girls Just Want To Have Fun","status":200,"ts":1542778219796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":11,"lastName":"Davidson","length":236.09424,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"Canada","status":200,"ts":1542778408796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Swirlies","auth":"Logged In","firstName":"Braden","gender":"M","itemInSession":0,"lastName":"Parker","length":391.23546,"level":"free","location":"Youngstown-Warren-Boardman, OH-PA","method":"PUT","page":"NextSong","registration":1540999292796.0,"sessionId":749,"song":"House Of Pancake","status":200,"ts":1542778435796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"74"} {"artist":"The Knife","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":33,"lastName":"Harrell","length":292.54485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Silent Shout","status":200,"ts":1542778447796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Miley Cyrus","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":12,"lastName":"Davidson","length":237.60934,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"I Miss You","status":200,"ts":1542778644796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Eddie Vedder","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":34,"lastName":"Harrell","length":151.77098,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Long Nights","status":200,"ts":1542778739796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Something Corporate","auth":"Logged In","firstName":"Braden","gender":"M","itemInSession":1,"lastName":"Parker","length":255.18975,"level":"free","location":"Youngstown-Warren-Boardman, OH-PA","method":"PUT","page":"NextSong","registration":1540999292796.0,"sessionId":749,"song":"If You C Jordan","status":200,"ts":1542778826796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"74"} {"artist":"John Mayer","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":13,"lastName":"Davidson","length":269.71383,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"Heartbreak Warfare","status":200,"ts":1542778881796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"DAVE MATTHEWS BAND","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":35,"lastName":"Harrell","length":577.74975,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"The Maker","status":200,"ts":1542778890796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Alice Cooper","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":14,"lastName":"Davidson","length":207.17669,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"School's Out","status":200,"ts":1542779150796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":null,"auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":15,"lastName":"Davidson","length":null,"level":"paid","location":"Longview, TX","method":"PUT","page":"Logout","registration":1540810646796.0,"sessionId":64,"song":null,"status":307,"ts":1542779151796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":16,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":64,"song":null,"status":200,"ts":1542779331796,"userAgent":null,"userId":""} {"artist":"Victor Manuelle","auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":0,"lastName":"Rosales","length":277.99465,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541059521796.0,"sessionId":609,"song":"Por Ella","status":200,"ts":1542779457796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"The Streets","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":36,"lastName":"Harrell","length":280.81587,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"What Is He Thinking?","status":200,"ts":1542779467796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":17,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":64,"song":null,"status":200,"ts":1542779482796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":18,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":64,"song":null,"status":200,"ts":1542779502796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":19,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":64,"song":null,"status":307,"ts":1542779503796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":20,"lastName":"Davidson","length":null,"level":"paid","location":"Longview, TX","method":"GET","page":"Home","registration":1540810646796.0,"sessionId":64,"song":null,"status":200,"ts":1542779561796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Make Do And Mend","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":21,"lastName":"Davidson","length":200.12363,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"No Words","status":200,"ts":1542779604796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Sara Bareilles","auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":1,"lastName":"Rosales","length":260.8322,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541059521796.0,"sessionId":609,"song":"Love Song","status":200,"ts":1542779734796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"Jason Derulo","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":37,"lastName":"Harrell","length":222.61506,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Whatcha Say","status":200,"ts":1542779747796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"USS (Ubiquitous Synergy Seeker)","auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":22,"lastName":"Davidson","length":307.61751,"level":"paid","location":"Longview, TX","method":"PUT","page":"NextSong","registration":1540810646796.0,"sessionId":64,"song":"Man Makes The Zoo","status":200,"ts":1542779804796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Peter Bjorn And John","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":38,"lastName":"Harrell","length":276.89751,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Blue period Picasso","status":200,"ts":1542779969796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Amiya","gender":"F","itemInSession":23,"lastName":"Davidson","length":null,"level":"paid","location":"Longview, TX","method":"GET","page":"Home","registration":1540810646796.0,"sessionId":64,"song":null,"status":200,"ts":1542780003796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"65"} {"artist":"Paramore","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":39,"lastName":"Harrell","length":267.65016,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"The Only Exception (Album Version)","status":200,"ts":1542780245796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":40,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":797,"song":null,"status":200,"ts":1542780266796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Empire Of The Sun","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":41,"lastName":"Harrell","length":413.59628,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Walking On A Dream (Kaskade Remix (Edit))","status":200,"ts":1542780512796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Zac Brown Band","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":42,"lastName":"Harrell","length":167.99302,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Mary (Album)","status":200,"ts":1542780925796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"This Beautiful Republic","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":43,"lastName":"Harrell","length":172.48608,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Last Second Chance","status":200,"ts":1542781092796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Young MC","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":44,"lastName":"Harrell","length":291.36934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Got More Rhymes","status":200,"ts":1542781264796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Man Man","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":45,"lastName":"Harrell","length":213.83791,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Engwish Bwudd","status":200,"ts":1542781555796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Alexi Murdoch","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":46,"lastName":"Harrell","length":155.95057,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Love You More","status":200,"ts":1542781768796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Miike Snow","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":47,"lastName":"Harrell","length":263.88853,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Animal","status":200,"ts":1542781923796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Black Angels","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":48,"lastName":"Harrell","length":231.81016,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Bloodhounds On My Trail","status":200,"ts":1542782186796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"TV On The Radio","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":49,"lastName":"Harrell","length":255.73832,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Shout Me Out","status":200,"ts":1542782417796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":50,"lastName":"Harrell","length":146.52036,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Portobello Road","status":200,"ts":1542782672796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Alanis Morissette","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":51,"lastName":"Harrell","length":275.56526,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Surrendering (Album Version)","status":200,"ts":1542782818796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Mariah Carey","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":52,"lastName":"Harrell","length":652.40771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Anytime You Need A Friend","status":200,"ts":1542783093796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":53,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":797,"song":null,"status":200,"ts":1542783112796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":54,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Downgrade","registration":1540472624796.0,"sessionId":797,"song":null,"status":200,"ts":1542783171796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Pavement","auth":"Logged In","firstName":"Kynnedi","gender":"F","itemInSession":0,"lastName":"Sanchez","length":99.16036,"level":"free","location":"Cedar Rapids, IA","method":"PUT","page":"NextSong","registration":1541079034796.0,"sessionId":631,"song":"Mercy:The Laundromat","status":200,"ts":1542783174796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_8_5) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"89"} {"artist":"The Rumble Strips","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":55,"lastName":"Harrell","length":152.00608,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Girls And Boys In Love","status":200,"ts":1542783745796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Marilyn Manson","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":56,"lastName":"Harrell","length":218.8273,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"The Beautiful People","status":200,"ts":1542783897796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Iration","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":57,"lastName":"Harrell","length":190.56281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Time Bomb","status":200,"ts":1542784115796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Camila","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":58,"lastName":"Harrell","length":308.00934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Coleccionista De Canciones","status":200,"ts":1542784305796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Evanescence","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":59,"lastName":"Harrell","length":290.01098,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Lose Control","status":200,"ts":1542784613796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":795,"song":null,"status":200,"ts":1542784793796,"userAgent":null,"userId":""} {"artist":"Uniikki","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":60,"lastName":"Harrell","length":220.00281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"Paa vauhtii","status":200,"ts":1542784903796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"keller williams","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":61,"lastName":"Harrell","length":230.39955,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":797,"song":"221","status":200,"ts":1542785123796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":744,"song":null,"status":200,"ts":1542786024796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Avett Brothers","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":271.0722,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"The Perfect Space","status":200,"ts":1542786093796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Tracy Bonham","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":180.74077,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Mother Mother","status":200,"ts":1542786364796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":3,"lastName":"Rodriguez","length":236.09424,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Canada","status":200,"ts":1542786544796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":4,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":744,"song":null,"status":200,"ts":1542786595796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Radiohead","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":5,"lastName":"Rodriguez","length":231.91465,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"(Nice Dream)","status":200,"ts":1542786780796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Colbie Caillat","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":6,"lastName":"Rodriguez","length":203.98975,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Magic","status":200,"ts":1542787011796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Fabolous \/ Ne-Yo","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":7,"lastName":"Rodriguez","length":253.59628,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Make Me Better","status":200,"ts":1542787214796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Muse","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":8,"lastName":"Rodriguez","length":164.67546,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Minimum","status":200,"ts":1542787467796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Gr\u00c3\u0083\u00c2\u00a9gory Lemarchal","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":9,"lastName":"Rodriguez","length":239.20281,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Mon Ange","status":200,"ts":1542787631796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Counting Crows","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":10,"lastName":"Rodriguez","length":272.79628,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Mr. Jones","status":200,"ts":1542787870796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Richard Ashcroft","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":11,"lastName":"Rodriguez","length":375.03955,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Money To Burn","status":200,"ts":1542788142796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"In This Moment","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":12,"lastName":"Rodriguez","length":226.40281,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Prayers","status":200,"ts":1542788517796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Lionel Rogg","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":13,"lastName":"Rodriguez","length":172.38159,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Die Kunst der Fuge_ BWV 1080 (2007 Digital Remaster): Contrapunctus XVII - Inversus","status":200,"ts":1542788743796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The O.C. Supertones","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":14,"lastName":"Rodriguez","length":199.8624,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Revolution","status":200,"ts":1542788915796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Radiohead","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":15,"lastName":"Rodriguez","length":291.21261,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"I Might Be Wrong","status":200,"ts":1542789114796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Eric Prydz vs Floyd","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":16,"lastName":"Rodriguez","length":201.1424,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Proper Education","status":200,"ts":1542789405796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Devin Townsend","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":17,"lastName":"Rodriguez","length":221.17832,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Christeen","status":200,"ts":1542789606796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Battles","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":18,"lastName":"Rodriguez","length":511.92118,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"TRAS","status":200,"ts":1542789827796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":728,"song":null,"status":200,"ts":1542790059796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":728,"song":null,"status":307,"ts":1542790060796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":2,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":728,"song":null,"status":200,"ts":1542790128796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Lloyd","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":3,"lastName":"Jones","length":225.98485,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":728,"song":"Party All Over Your Body","status":200,"ts":1542790185796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Kruiz","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":19,"lastName":"Rodriguez","length":433.31873,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Possessed","status":200,"ts":1542790338796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Anthony Hamilton","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":4,"lastName":"Jones","length":232.54159,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":728,"song":"Can't Let Go","status":200,"ts":1542790410796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Rob Zombie","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":5,"lastName":"Jones","length":220.13342,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":728,"song":"Superbeast","status":200,"ts":1542790642796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":6,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":728,"song":null,"status":200,"ts":1542790649796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Sheryl Crow","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":20,"lastName":"Rodriguez","length":298.78812,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Picture","status":200,"ts":1542790771796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Inimigos Da HP","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":7,"lastName":"Jones","length":250.56608,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":728,"song":"Caca E Cacador","status":200,"ts":1542790862796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Yellowcard","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":21,"lastName":"Rodriguez","length":227.21261,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Space Travel","status":200,"ts":1542791069796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Pussycat Dolls","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":8,"lastName":"Jones","length":235.83302,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":728,"song":"How Many Times_ How Many Lies","status":200,"ts":1542791112796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":22,"lastName":"Rodriguez","length":214.67383,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"One Time","status":200,"ts":1542791296796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bombay Bicycle Club","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":9,"lastName":"Jones","length":245.75955,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":728,"song":"Always Like This","status":200,"ts":1542791347796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"B.o.B","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":23,"lastName":"Rodriguez","length":269.63546,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Nothin' On You [feat. Bruno Mars] (Album Version)","status":200,"ts":1542791510796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Death Cab for Cutie","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":10,"lastName":"Jones","length":119.40526,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":728,"song":"You Can Do Better Than Me (Album Version)","status":200,"ts":1542791592796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":11,"lastName":"Jones","length":301.13914,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":728,"song":"Me_ Myself And I","status":200,"ts":1542791711796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":24,"lastName":"Rodriguez","length":185.46893,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Cover Me","status":200,"ts":1542791779796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Audioslave","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":0,"lastName":"Santana","length":295.47057,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":787,"song":"Like A Stone","status":200,"ts":1542791804796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":null,"auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":1,"lastName":"Santana","length":null,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"Logout","registration":1540856629796.0,"sessionId":787,"song":null,"status":307,"ts":1542791805796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":787,"song":null,"status":200,"ts":1542791844796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":787,"song":null,"status":200,"ts":1542791846796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":787,"song":null,"status":307,"ts":1542791847796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":5,"lastName":"Santana","length":null,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"GET","page":"Home","registration":1540856629796.0,"sessionId":787,"song":null,"status":200,"ts":1542791860796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Rogue Wave","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":0,"lastName":"Griffin","length":223.58159,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":739,"song":"Publish My Love (Album Version)","status":200,"ts":1542791865796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":1,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Help","registration":1541057188796.0,"sessionId":739,"song":null,"status":200,"ts":1542791879796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":25,"lastName":"Rodriguez","length":199.88853,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Not Fair","status":200,"ts":1542791964796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":12,"lastName":"Jones","length":223.37261,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":728,"song":"Sleep Through The Static","status":200,"ts":1542792012796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Alicia Keys featuring Tony! Toni! Ton\u00c3\u0083\u00c2\u00a9! and Jermaine Paul","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":2,"lastName":"Griffin","length":284.15955,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":739,"song":"Diary","status":200,"ts":1542792088796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Professor Longhair","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":26,"lastName":"Rodriguez","length":179.77424,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Hey Little Girl","status":200,"ts":1542792163796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Helloween","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":13,"lastName":"Jones","length":266.10893,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":728,"song":"Murderer","status":200,"ts":1542792235796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":14,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Help","registration":1541062818796.0,"sessionId":728,"song":null,"status":200,"ts":1542792276796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Arcade Fire","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":27,"lastName":"Rodriguez","length":267.80689,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Headlights Look Like Diamonds","status":200,"ts":1542792342796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Charlie Hall","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":3,"lastName":"Griffin","length":286.82404,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":739,"song":"Your Glory Endures Forever (Flying Into Daybreak Album Version)","status":200,"ts":1542792372796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Big Daddy Weave","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":15,"lastName":"Jones","length":265.76934,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":728,"song":"You're Worthy Of My Praise - Album Version","status":200,"ts":1542792501796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Gerbils","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":28,"lastName":"Rodriguez","length":27.01016,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"(iii)","status":200,"ts":1542792609796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Pretenders","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":29,"lastName":"Rodriguez","length":181.83791,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Love's a Mystery (LP Version)","status":200,"ts":1542792636796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Robert Palmer","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":4,"lastName":"Griffin","length":227.97016,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":739,"song":"Casting A Spell (Remixed) (1998 Digital Remaster)","status":200,"ts":1542792658796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":30,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":744,"song":null,"status":200,"ts":1542792740796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Blind Blake","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":16,"lastName":"Jones","length":169.40363,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":728,"song":"He\u0019s In The Jailhouse Now","status":200,"ts":1542792766796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Fall Out Boy","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":31,"lastName":"Rodriguez","length":229.0673,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Sugar_ We're Goin Down","status":200,"ts":1542792817796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":32,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":744,"song":null,"status":200,"ts":1542792860796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Insane Clown Posse","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":5,"lastName":"Griffin","length":192.44363,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":739,"song":"Superballs","status":200,"ts":1542792885796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Koch","length":239.3073,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"You're The One","status":200,"ts":1542792981796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":17,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Downgrade","registration":1541062818796.0,"sessionId":728,"song":null,"status":200,"ts":1542793044796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Modjo","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":33,"lastName":"Rodriguez","length":305.44934,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Lady (Hear Me Tonight)","status":200,"ts":1542793046796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bill Medley & Jennifer Warnes","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":6,"lastName":"Griffin","length":290.32444,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":739,"song":"(I've Had) The Time Of My Life","status":200,"ts":1542793077796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Dilated Peoples Featuring Kanye West","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":18,"lastName":"Jones","length":245.15873,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":728,"song":"This Way","status":200,"ts":1542793114796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Donavon Frankenreiter","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Koch","length":362.03057,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Fool","status":200,"ts":1542793220796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Cher","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":34,"lastName":"Rodriguez","length":166.94812,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"I Go To Sleep (2005 Digital Remaster)","status":200,"ts":1542793351796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":7,"lastName":"Griffin","length":257.54077,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":739,"song":"Imma Be","status":200,"ts":1542793367796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Tab Benoit","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":35,"lastName":"Rodriguez","length":221.09995,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Jambalaya","status":200,"ts":1542793517796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Staff Benda Bilili","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Koch","length":405.05424,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Marguerite","status":200,"ts":1542793582796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":8,"lastName":"Griffin","length":348.57751,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":739,"song":"Undo","status":200,"ts":1542793624796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Kid Cudi \/ Kanye West \/ Common","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":36,"lastName":"Rodriguez","length":237.76608,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Make Her Say","status":200,"ts":1542793738796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Pereza","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":37,"lastName":"Rodriguez","length":188.60363,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Lo Que Tengo Yo Adentro","status":200,"ts":1542793975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Hot Chip","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Koch","length":260.0224,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Brothers","status":200,"ts":1542793987796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Angels and Airwaves","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":38,"lastName":"Rodriguez","length":302.05342,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"The Gift","status":200,"ts":1542794163796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Lit","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Koch","length":169.03791,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"My Own Worst Enemy","status":200,"ts":1542794247796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"MGMT","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":5,"lastName":"Koch","length":264.17587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Time To Pretend","status":200,"ts":1542794416796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Otto von Schirach","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":39,"lastName":"Rodriguez","length":272.06485,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Dance Like A hoe","status":200,"ts":1542794465796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Tinchy Stryder \/ Taio Cruz","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":6,"lastName":"Koch","length":195.36934,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Take Me Back","status":200,"ts":1542794680796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Just Jack","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":40,"lastName":"Rodriguez","length":295.91465,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Starz In Their Eyes","status":200,"ts":1542794737796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":7,"lastName":"Koch","length":233.89995,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Love Story","status":200,"ts":1542794875796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":0,"lastName":"Finley","length":null,"level":"free","location":"Richmond, VA","method":"GET","page":"Home","registration":1541013292796.0,"sessionId":762,"song":null,"status":200,"ts":1542794990796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":"ISRAEL & NEW BREED","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":41,"lastName":"Rodriguez","length":120.52853,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Take the Limits Off","status":200,"ts":1542795032796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Hootie And The Blowfish","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":8,"lastName":"Koch","length":227.05587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Only Wanna Be With You (LP Version)","status":200,"ts":1542795108796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"T.Love","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":42,"lastName":"Rodriguez","length":271.09832,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Gnijacy Swiat","status":200,"ts":1542795152796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Mayday Parade","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":209.8673,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":800,"song":"Walk On Water Or Drown (Album)","status":200,"ts":1542795222796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Usher Featuring Lil' Jon & Ludacris","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":9,"lastName":"Koch","length":250.38322,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Yeah!","status":200,"ts":1542795335796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Michael Bubl\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":43,"lastName":"Rodriguez","length":253.88363,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Moondance (Album Version)","status":200,"ts":1542795423796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Notorious B.I.G.","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":230.03383,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":800,"song":"Hypnotize(Album Version)","status":200,"ts":1542795431796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Aphex Twin","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":10,"lastName":"Koch","length":290.97751,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Heliospan","status":200,"ts":1542795585796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":800,"song":null,"status":200,"ts":1542795592796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"ATB","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":3,"lastName":"Smith","length":191.7122,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":800,"song":"Rising Moon","status":200,"ts":1542795661796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Spice Girls","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":44,"lastName":"Rodriguez","length":240.97914,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"2 Become 1","status":200,"ts":1542795676796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":11,"lastName":"Koch","length":265.76934,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Creil City","status":200,"ts":1542795875796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Franz Ferdinand","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":45,"lastName":"Rodriguez","length":233.06404,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"The Fallen (Ruined By Justice)","status":200,"ts":1542795916796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Marc Et Claude","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":12,"lastName":"Koch","length":220.86485,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"I Need Your Lovin' (Like The Sunshine) (Radio Edit)","status":200,"ts":1542796140796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Telex","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":46,"lastName":"Rodriguez","length":44.48608,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":744,"song":"Clich\u00c3\u0083\u00c2\u00a9","status":200,"ts":1542796149796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Laurie Berkner","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":13,"lastName":"Koch","length":169.35138,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Froggie Went a-Courtin'","status":200,"ts":1542796360796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"DMX","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":14,"lastName":"Koch","length":444.70812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Ready To Meet Him","status":200,"ts":1542796529796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Phil Collins","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":15,"lastName":"Koch","length":322.24608,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Another Day In Paradise","status":200,"ts":1542796973796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Vanessa Carlton","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":16,"lastName":"Koch","length":237.42649,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"A Thousand Miles","status":200,"ts":1542797295796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Lady GaGa","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":17,"lastName":"Koch","length":274.18077,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Alejandro","status":200,"ts":1542797532796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Tom Petty And The Heartbreakers","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":18,"lastName":"Koch","length":259.76118,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"A Woman In Love (It's Not Me)","status":200,"ts":1542797806796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Carcass","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":19,"lastName":"Koch","length":175.33342,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Pyosisified (Rotten To The Gore)","status":200,"ts":1542798065796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Car Is On Fire","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":20,"lastName":"Koch","length":218.69669,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Manuel","status":200,"ts":1542798240796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":21,"lastName":"Koch","length":224.67873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Secrets","status":200,"ts":1542798458796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":22,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Downgrade","registration":1541048010796.0,"sessionId":764,"song":null,"status":200,"ts":1542798516796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":23,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"Submit Downgrade","registration":1541048010796.0,"sessionId":764,"song":null,"status":307,"ts":1542798517796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":24,"lastName":"Koch","length":null,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":764,"song":null,"status":200,"ts":1542798537796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Coko featuring Kirk Franklin","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":25,"lastName":"Koch","length":249.3122,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"I Get Joy","status":200,"ts":1542798682796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":26,"lastName":"Koch","length":null,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Upgrade","registration":1541048010796.0,"sessionId":764,"song":null,"status":200,"ts":1542798744796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":27,"lastName":"Koch","length":null,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"Submit Upgrade","registration":1541048010796.0,"sessionId":764,"song":null,"status":307,"ts":1542798745796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":28,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":764,"song":null,"status":200,"ts":1542798812796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":29,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Settings","registration":1541048010796.0,"sessionId":764,"song":null,"status":200,"ts":1542798860796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":30,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"Save Settings","registration":1541048010796.0,"sessionId":764,"song":null,"status":307,"ts":1542798861796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":31,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":764,"song":null,"status":200,"ts":1542798952796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Script","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":32,"lastName":"Koch","length":260.67546,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Breakeven","status":200,"ts":1542799016796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Daughtry","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":33,"lastName":"Koch","length":255.65995,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Home","status":200,"ts":1542799276796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Alceu Valen\u00c3\u0083\u00c2\u00a7a","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":34,"lastName":"Koch","length":162.58567,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Recado Falado (Metr\u00c3\u0083\u00c2\u00b4 Da Saudade)","status":200,"ts":1542799531796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"King Diamond","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":35,"lastName":"Koch","length":101.22404,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Introductions","status":200,"ts":1542799693796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Avenged Sevenfold","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":36,"lastName":"Koch","length":288.23465,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Scream (Album Version)","status":200,"ts":1542799794796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Celtic Woman","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":37,"lastName":"Koch","length":142.65424,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Spanish Lady (Live From Slane Castle)","status":200,"ts":1542800082796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Ministry","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":38,"lastName":"Koch","length":222.51057,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Jesus Built My Hotrod (Short_ Pusillanimous_ So-They-Can-Fit-More Commercials-On-The-Radio Edit)","status":200,"ts":1542800224796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Pavel Dobes","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":39,"lastName":"Koch","length":132.64934,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Vzpominky IV.","status":200,"ts":1542800446796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Prince & The New Power Generation","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":40,"lastName":"Koch","length":304.79628,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Nothing Compares 2 U","status":200,"ts":1542800578796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Nickelback","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":41,"lastName":"Koch","length":217.62567,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Savin' Me","status":200,"ts":1542800882796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"John Mayer","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":42,"lastName":"Koch","length":161.56689,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"I'm Gonna Find Another You","status":200,"ts":1542801099796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":43,"lastName":"Koch","length":197.45914,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Him","status":200,"ts":1542801260796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Radiohead","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":44,"lastName":"Koch","length":317.93587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Weird Fishes\/Arpeggi","status":200,"ts":1542801457796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Blink-182","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":45,"lastName":"Koch","length":166.60853,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Untitled","status":200,"ts":1542801774796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Jane's Addiction","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":46,"lastName":"Koch","length":309.86404,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Classic Girl (2006 Remastered Album Version)","status":200,"ts":1542801940796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":47,"lastName":"Koch","length":239.3073,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"You're The One","status":200,"ts":1542802249796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Muse","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":48,"lastName":"Koch","length":209.50159,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Supermassive Black Hole (Twilight Soundtrack Version)","status":200,"ts":1542802488796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Madonna","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":49,"lastName":"Koch","length":443.11465,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Sorry (Man With Guitar Mix)","status":200,"ts":1542802697796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Hummersqueal","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":50,"lastName":"Koch","length":249.96526,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Estoy harto de t\u00c3\u0083\u00c2\u00ad","status":200,"ts":1542803140796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Evanescence","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":51,"lastName":"Koch","length":236.12036,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Bring Me To Life","status":200,"ts":1542803389796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Charttraxx Karaoke","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":52,"lastName":"Koch","length":225.17506,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Fireflies","status":200,"ts":1542803625796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"R\u00c3\u0083\u00c2\u00b3is\u00c3\u0083\u00c2\u00adn Murphy","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":53,"lastName":"Koch","length":277.62893,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Body Language","status":200,"ts":1542803850796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":54,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Help","registration":1541048010796.0,"sessionId":764,"song":null,"status":200,"ts":1542803869796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Sugarland","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":55,"lastName":"Koch","length":242.1024,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Joey","status":200,"ts":1542804127796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Astrud Gilberto","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":56,"lastName":"Koch","length":371.53914,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"All I've Got","status":200,"ts":1542804369796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Massive Attack","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":57,"lastName":"Koch","length":316.49914,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Karmacoma","status":200,"ts":1542804740796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Tangent","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":58,"lastName":"Koch","length":1328.69179,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"In Earnest (live)","status":200,"ts":1542805056796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Cameo","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":59,"lastName":"Koch","length":211.98322,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Word Up!","status":200,"ts":1542806384796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Nelly \/ Jaheim","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":60,"lastName":"Koch","length":336.56118,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"My Place","status":200,"ts":1542806595796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Harris","length":342.54322,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":543,"song":"Around The World \/ Harder Better Faster Stronger","status":200,"ts":1542806877796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Dashboard Confessional","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":61,"lastName":"Koch","length":275.01669,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Dusk And Summer","status":200,"ts":1542806931796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":806,"song":null,"status":200,"ts":1542807119796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"My Chemical Romance","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":203.04934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":806,"song":"Helena (So Long & Goodnight) (Album Version)","status":200,"ts":1542807123796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Laura Marling","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":62,"lastName":"Koch","length":220.99546,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Cross Your Fingers (Single Version)","status":200,"ts":1542807206796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Charttraxx Karaoke","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Harris","length":225.17506,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":543,"song":"Fireflies","status":200,"ts":1542807219796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"David Gray","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":313.59955,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":806,"song":"Sail Away","status":200,"ts":1542807326796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Notorious B.I.G.","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":63,"lastName":"Koch","length":230.03383,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Hypnotize(Album Version)","status":200,"ts":1542807426796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":2,"lastName":"Harris","length":219.66322,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":543,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1542807444796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":3,"lastName":"Harris","length":null,"level":"free","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1541097374796.0,"sessionId":543,"song":null,"status":200,"ts":1542807591796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Lisa Hannigan","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":246.96118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":806,"song":"Lille","status":200,"ts":1542807639796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Alesana","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":64,"lastName":"Koch","length":317.962,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Apology","status":200,"ts":1542807656796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Metallica \/ Marianne Faithfull","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":279.11791,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":806,"song":"The Memory Remains","status":200,"ts":1542807885796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Avril Lavigne","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":65,"lastName":"Koch","length":242.41587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"My Happy Ending","status":200,"ts":1542807973796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":805,"song":null,"status":200,"ts":1542808117796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":805,"song":null,"status":307,"ts":1542808118796,"userAgent":null,"userId":""} {"artist":"Bon Jovi","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":250.69669,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":806,"song":"Livin' On A Prayer","status":200,"ts":1542808164796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Radiohead","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":66,"lastName":"Koch","length":354.66404,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"How To Disappear Completely","status":200,"ts":1542808215796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Veracocha","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":506.93179,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":715,"song":"Carte Blanche","status":200,"ts":1542808324796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":805,"song":null,"status":200,"ts":1542808343796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":277.15873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":806,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1542808414796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"GET","page":"Home","registration":1540006905796.0,"sessionId":714,"song":null,"status":200,"ts":1542808550796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Dido","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":67,"lastName":"Koch","length":217.83465,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Thank You","status":200,"ts":1542808569796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":68,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":764,"song":null,"status":200,"ts":1542808606796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Propagandhi","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":139.20608,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":805,"song":"Oka Everywhere","status":200,"ts":1542808664796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Rick James","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":1,"lastName":"Arellano","length":263.60118,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":714,"song":"Ghetto Life","status":200,"ts":1542808673796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Emil Gilels\/Orchestre de la Soci\u00c3\u0083\u00c2\u00a9t\u00c3\u0083\u00c2\u00a9 des Concerts du Conservatoire\/Andr\u00c3\u0083\u00c2\u00a9 Cluytens","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":375.19628,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":806,"song":"Piano Concerto No. 2 in G minor Op. 22 (2006 Digital Remaster): III. Presto","status":200,"ts":1542808691796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Turisas","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":69,"lastName":"Koch","length":261.92934,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Battle Metal","status":200,"ts":1542808786796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Box Car Racer","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":196.93669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":805,"song":"There Is","status":200,"ts":1542808803796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Muse","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":209.50159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":805,"song":"Supermassive Black Hole (Twilight Soundtrack Version)","status":200,"ts":1542808999796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Otis Rush","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":70,"lastName":"Koch","length":176.63955,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Checking On My Baby","status":200,"ts":1542809047796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Mercyful Fate","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":235.80689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":806,"song":"Listen To The Bell","status":200,"ts":1542809066796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Skye Sweetnam","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":71,"lastName":"Koch","length":158.40608,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Sharada","status":200,"ts":1542809223796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Ida Corr Vs Fedde Le Grand","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":150.46485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":806,"song":"Let Me Think About It","status":200,"ts":1542809301796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kurt Vile","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":72,"lastName":"Koch","length":202.34404,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Best Love","status":200,"ts":1542809381796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Steinski","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":101.72036,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":806,"song":"Product Of The Environment (Redfern Gowanus Electro Mix)","status":200,"ts":1542809451796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Error","registration":1540472624796.0,"sessionId":806,"song":null,"status":404,"ts":1542809469796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Shaggy \/ Brian & Tony Gold","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":73,"lastName":"Koch","length":199.94077,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Hey Sexy Lady","status":200,"ts":1542809583796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bread","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":74,"lastName":"Koch","length":190.53669,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Look What You've Done (LP Version)","status":200,"ts":1542809782796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":75,"lastName":"Koch","length":260.20526,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Be With You","status":200,"ts":1542809972796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Divinyls","auth":"Logged In","firstName":"Zachary","gender":"M","itemInSession":0,"lastName":"Thomas","length":227.68281,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540644861796.0,"sessionId":592,"song":"I Touch Myself","status":200,"ts":1542810192796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.7; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"19"} {"artist":"Erin Bode","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":76,"lastName":"Koch","length":252.05506,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":764,"song":"Here_ There And Everywhere","status":200,"ts":1542810232796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Drowning Pool","auth":"Logged In","firstName":"Zachary","gender":"M","itemInSession":1,"lastName":"Thomas","length":229.35465,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540644861796.0,"sessionId":592,"song":"Reason I'm Alive (Explicit)","status":200,"ts":1542810419796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.7; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"19"} {"artist":"Brujeria","auth":"Logged In","firstName":"Zachary","gender":"M","itemInSession":2,"lastName":"Thomas","length":143.25506,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540644861796.0,"sessionId":592,"song":"Pititis_ Te Invoco (Album Version)","status":200,"ts":1542810648796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.7; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"19"} {"artist":"Joyce Cooling","auth":"Logged In","firstName":"Zachary","gender":"M","itemInSession":3,"lastName":"Thomas","length":248.11057,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540644861796.0,"sessionId":592,"song":"It's Time I Go (Jazz)","status":200,"ts":1542810791796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.7; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"19"} {"artist":"The White Stripes","auth":"Logged In","firstName":"Zachary","gender":"M","itemInSession":4,"lastName":"Thomas","length":160.31302,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540644861796.0,"sessionId":592,"song":"Blue Orchid","status":200,"ts":1542811039796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.7; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"19"} {"artist":"R.I.O.","auth":"Logged In","firstName":"Zachary","gender":"M","itemInSession":5,"lastName":"Thomas","length":217.12934,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540644861796.0,"sessionId":592,"song":"When The Sun Comes Down","status":200,"ts":1542811199796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.7; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"19"} {"artist":"Bap","auth":"Logged In","firstName":"Zachary","gender":"M","itemInSession":6,"lastName":"Thomas","length":277.21098,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540644861796.0,"sessionId":592,"song":"F\u00c3\u0083\u00c2\u00bcr Maria (Album Version)","status":200,"ts":1542811416796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.7; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"19"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":406.17751,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":811,"song":"Paradise City","status":200,"ts":1542811523796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"A3Bandas","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":107.10159,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":811,"song":"El arca de Noe","status":200,"ts":1542811929796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"System of a Down","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":0,"lastName":"Benson","length":205.7922,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":768,"song":"Sad Statue","status":200,"ts":1542813995796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Ghostland Observatory","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":1,"lastName":"Benson","length":224.26077,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":768,"song":"Stranger Lover","status":200,"ts":1542814200796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Evergreen Terrace","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":2,"lastName":"Benson","length":172.38159,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":768,"song":"Zero","status":200,"ts":1542814424796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":3,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"Help","registration":1540907087796.0,"sessionId":768,"song":null,"status":200,"ts":1542814453796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":0,"lastName":"Cook","length":248.55465,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":770,"song":"Human Behaviour","status":200,"ts":1542816994796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Evanescence","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":1,"lastName":"Cook","length":279.27465,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":770,"song":"Tourniquet","status":200,"ts":1542817242796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":799,"song":null,"status":200,"ts":1542819625796,"userAgent":null,"userId":""} {"artist":"The Rascals","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":179.33016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"People Got To Be Free","status":200,"ts":1542820667796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"A Day To Remember","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":213.81179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"My Life For Hire","status":200,"ts":1542820846796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":277.15873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1542821059796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Train","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":213.68118,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Shelter Me","status":200,"ts":1542821336796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Unearth","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":283.58485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Letting Go","status":200,"ts":1542821528796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":459.20608,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Sympathy For The Devil","status":200,"ts":1542821549796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Junior Kelly","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":262.26893,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Jah Jah Live On","status":200,"ts":1542821811796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":201.79546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Revelry","status":200,"ts":1542822008796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eric Johnson","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":183.37914,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"S.R.V.","status":200,"ts":1542822073796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Downgrade","registration":1540472624796.0,"sessionId":817,"song":null,"status":200,"ts":1542822090796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Pretend It's December Choir","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":265.53424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"It's Christmas So We'll Stop (Choir Version)","status":200,"ts":1542822209796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Harmonia","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":655.77751,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Sehr kosmisch","status":200,"ts":1542822256796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Vampire Weekend","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":286.17098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Giving Up The Gun","status":200,"ts":1542822474796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Great White","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":357.14567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"House Of Broken Love","status":200,"ts":1542822760796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sublime","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":172.5122,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Right Back","status":200,"ts":1542822911796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Andres Calamaro","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":276.13995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Flaca","status":200,"ts":1542823083796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Avril Lavigne","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":240.48281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"When You're Gone","status":200,"ts":1542823117796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Metronomy","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":315.24526,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Heartbreaker [Discodeine Remix]","status":200,"ts":1542823357796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Andres Calamaro","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":278.12526,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"El Cantante","status":200,"ts":1542823359796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Good Clean Fun","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":116.61016,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"It\u0019s Fun To Be A Vampire&","status":200,"ts":1542823637796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Zero 7","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":259.05587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Mr McGee","status":200,"ts":1542823672796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Stranglers","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":211.90485,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Golden Brown","status":200,"ts":1542823753796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Snow Patrol","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":197.09342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Shut Your Eyes","status":200,"ts":1542823931796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Mondo Marcio","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":218.06975,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Il Solo Rimasto","status":200,"ts":1542823964796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Curtis Mayfield","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":284.99546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Hey_ Baby_ Give It To Me All","status":200,"ts":1542824128796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Enrique Iglesias","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":301.87057,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Addicted","status":200,"ts":1542824182796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Steve Lukather","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":355.73506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Jammin' With Jesus","status":200,"ts":1542824412796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cocoa Brovas","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":12,"lastName":"Harrell","length":60.73424,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"What They Call Him (Skit)","status":200,"ts":1542824483796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Carlos Y Jos\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":13,"lastName":"Harrell","length":184.42404,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"La Mata De Sandia","status":200,"ts":1542824543796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Stars","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":14,"lastName":"Harrell","length":225.90649,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Take Me To The Riot","status":200,"ts":1542824727796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":200.22812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Fuck Me Pumps","status":200,"ts":1542824767796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Shakira","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":15,"lastName":"Harrell","length":145.84118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Pienso En Ti","status":200,"ts":1542824952796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":274.62485,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Fire It Up","status":200,"ts":1542824967796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":16,"lastName":"Harrell","length":231.81016,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Use Somebody","status":200,"ts":1542825097796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Jel","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":17,"lastName":"Cuevas","length":217.36444,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"No Solution","status":200,"ts":1542825241796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kashmir","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":17,"lastName":"Harrell","length":262.68689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"The Cynic","status":200,"ts":1542825328796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Tab Benoit","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":18,"lastName":"Cuevas","length":221.09995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Jambalaya","status":200,"ts":1542825458796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cartola","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":18,"lastName":"Harrell","length":127.242,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Tive Sim","status":200,"ts":1542825590796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Old Crow Medicine Show","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":19,"lastName":"Cuevas","length":231.73179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Wagon Wheel","status":200,"ts":1542825679796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"We The Kings","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":19,"lastName":"Harrell","length":155.42812,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Whoa","status":200,"ts":1542825717796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Nightwish","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":20,"lastName":"Harrell","length":259.34322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Bye Bye Beautiful","status":200,"ts":1542825872796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Sisqo","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":20,"lastName":"Cuevas","length":253.49179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Thong Song","status":200,"ts":1542825910796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Lil Wayne \/ Shanell","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":0,"lastName":"Smith","length":216.81587,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":468,"song":"American Star","status":200,"ts":1542825953796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Carnifex","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":21,"lastName":"Harrell","length":253.43955,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Heartless","status":200,"ts":1542826131796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Metallica","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":21,"lastName":"Cuevas","length":447.42485,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"One","status":200,"ts":1542826163796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"El Coyote Y Su Banda Tierra Santa","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":190.51057,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":694,"song":"Me Voy A Ir","status":200,"ts":1542826168796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Barrington Levy","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":1,"lastName":"Smith","length":196.89556,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":468,"song":"Poor Man Style","status":200,"ts":1542826169796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Hot Chip","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":2,"lastName":"Smith","length":280.5024,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":468,"song":"Don't Dance","status":200,"ts":1542826365796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"LCD Soundsystem","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":22,"lastName":"Harrell","length":461.89669,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"All My Friends","status":200,"ts":1542826384796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Marilyn Manson","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":22,"lastName":"Cuevas","length":232.09751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Angel With The Scabbed Wings","status":200,"ts":1542826610796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Tommy James And The Shondells","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":23,"lastName":"Harrell","length":173.73995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Hanky Panky (Mono)","status":200,"ts":1542826845796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Telefon Tel Aviv","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":24,"lastName":"Harrell","length":283.76771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"You Are The Worst Thing In The World","status":200,"ts":1542827018796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":25,"lastName":"Harrell","length":201.79546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Revelry","status":200,"ts":1542827301796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":23,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":816,"song":null,"status":200,"ts":1542827381796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Steve Hackett","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":26,"lastName":"Harrell","length":100.96281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"The Caretaker","status":200,"ts":1542827502796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":27,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Help","registration":1540472624796.0,"sessionId":817,"song":null,"status":200,"ts":1542827512796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Crests","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":28,"lastName":"Harrell","length":182.88281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"16 Candles","status":200,"ts":1542827602796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Los Concorde","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":29,"lastName":"Harrell","length":234.1873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Rompecabezas","status":200,"ts":1542827784796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The dB's","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":30,"lastName":"Harrell","length":118.41261,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Black And White","status":200,"ts":1542828018796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Octopus Project","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":31,"lastName":"Harrell","length":253.25669,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Marshall Examines His Carcass","status":200,"ts":1542828136796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Eminem","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":0,"lastName":"Williams","length":248.58077,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":626,"song":"Just Lose It","status":200,"ts":1542828162796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Candy Dulfer","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":24,"lastName":"Cuevas","length":244.00934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Big Girl","status":200,"ts":1542828324796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Matt Nathanson","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":32,"lastName":"Harrell","length":248.55465,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Sing Me Sweet","status":200,"ts":1542828389796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Sam Paglia","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":25,"lastName":"Cuevas","length":106.70975,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"The Day Lo Bianco Left Sicily","status":200,"ts":1542828568796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"David Bromberg","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":33,"lastName":"Harrell","length":146.36363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Sheebeg And Sheemore","status":200,"ts":1542828637796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"John Mayer","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":26,"lastName":"Cuevas","length":321.09669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"St. Patrick's Day","status":200,"ts":1542828674796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":34,"lastName":"Harrell","length":199.94077,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Human After All","status":200,"ts":1542828783796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":0,"lastName":"Harris","length":null,"level":"free","location":"Eugene, OR","method":"GET","page":"Home","registration":1540906915796.0,"sessionId":753,"song":null,"status":200,"ts":1542828842796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Il Divo","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":35,"lastName":"Harrell","length":229.8771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Unchained Melody (Senza Catene)","status":200,"ts":1542828982796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Van Der Graaf Generator","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":27,"lastName":"Cuevas","length":594.57261,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Killer","status":200,"ts":1542828995796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kardinal Offishall \/ Rihanna","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":36,"lastName":"Harrell","length":223.00689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Numba 1 (Tide Is High)","status":200,"ts":1542829211796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Ghostland Observatory","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":37,"lastName":"Harrell","length":266.10893,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Club Soda (Album)","status":200,"ts":1542829434796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Guus Meeuwis","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":28,"lastName":"Cuevas","length":219.19302,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Laat Mij In Die Waan","status":200,"ts":1542829589796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"John Mayer","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":38,"lastName":"Harrell","length":263.57506,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Free Fallin'","status":200,"ts":1542829700796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Support Lesbiens","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":29,"lastName":"Cuevas","length":195.26485,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Fisherman's Friend","status":200,"ts":1542829808796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sauce Money Featuring Memphis Bleek","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":39,"lastName":"Harrell","length":280.21506,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"What We Do (Explicit) (Feat. Memphis Bleek)","status":200,"ts":1542829963796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Carmen Consoli","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":30,"lastName":"Cuevas","length":288.7571,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Piccolo Cesare","status":200,"ts":1542830003796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Mac Lethal","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":40,"lastName":"Harrell","length":238.99383,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Know it All","status":200,"ts":1542830243796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Dear Hunter","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":31,"lastName":"Cuevas","length":228.85832,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Blood Of The Rose","status":200,"ts":1542830291796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Gaelic Storm","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":41,"lastName":"Harrell","length":163.23873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Tell Me Ma","status":200,"ts":1542830481796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Espers","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":32,"lastName":"Cuevas","length":598.282,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Flaming Telepaths","status":200,"ts":1542830519796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Craig David","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":42,"lastName":"Harrell","length":184.47628,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"One More Lie (Standing In The Shadows)","status":200,"ts":1542830644796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"La Monja Enana","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":43,"lastName":"Harrell","length":144.43057,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Villaping\u00c3\u0083\u00c2\u00bcino","status":200,"ts":1542830828796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The White Stripes","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":44,"lastName":"Harrell","length":231.81016,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Seven Nation Army (Album Version)","status":200,"ts":1542830972796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Disturbed","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":33,"lastName":"Cuevas","length":226.01098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"The Game (Amended Version)","status":200,"ts":1542831117796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Silent Stream Of Godless Elegy","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":45,"lastName":"Harrell","length":412.83873,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Tv\u00c3\u0083\u00c2\u00a1r\u00c3\u0083\u00c2\u00ad v Tv\u00c3\u0083\u00c2\u00a1r","status":200,"ts":1542831203796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Skream","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":34,"lastName":"Cuevas","length":258.45506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Tortured Soul","status":200,"ts":1542831343796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":35,"lastName":"Cuevas","length":136.54159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Molly's Chambers","status":200,"ts":1542831601796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":46,"lastName":"Harrell","length":185.3122,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"I'm Not Calling You A Liar","status":200,"ts":1542831615796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Joy Division","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":36,"lastName":"Cuevas","length":380.89098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"The Eternal","status":200,"ts":1542831737796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Iam","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":47,"lastName":"Harrell","length":278.22975,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Une Femme Seule","status":200,"ts":1542831800796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Adina Howard","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":48,"lastName":"Harrell","length":236.40771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":817,"song":"Horny For Your Love (LP Version)","status":200,"ts":1542832078796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"David Darling","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":37,"lastName":"Cuevas","length":313.0771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Minor Blue","status":200,"ts":1542832117796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cloud Cult","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":38,"lastName":"Cuevas","length":260.25751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"May Your Hearts Stay Strong","status":200,"ts":1542832430796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"FRANK T","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":39,"lastName":"Cuevas","length":24.60689,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Ele","status":200,"ts":1542832690796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Alceu Valen\u00c3\u0083\u00c2\u00a7a","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":40,"lastName":"Cuevas","length":162.58567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Recado Falado (Metr\u00c3\u0083\u00c2\u00b4 Da Saudade)","status":200,"ts":1542832714796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Tom Waits","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":41,"lastName":"Cuevas","length":190.92853,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Flash Pan Hunter","status":200,"ts":1542832876796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Bell","length":null,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"GET","page":"Home","registration":1540991795796.0,"sessionId":645,"song":null,"status":200,"ts":1542833030796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 10.0; Windows NT 6.2; WOW64; Trident\/6.0)","userId":"91"} {"artist":"Third World","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Bell","length":268.79955,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540991795796.0,"sessionId":645,"song":"1865 (96\u00c3\u0082\u00c2\u00ba In The Shade)","status":200,"ts":1542833047796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 10.0; Windows NT 6.2; WOW64; Trident\/6.0)","userId":"91"} {"artist":"Jill Scott","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":42,"lastName":"Cuevas","length":108.69506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Crown Royal","status":200,"ts":1542833066796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Temptations","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":43,"lastName":"Cuevas","length":246.88281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Ball Of Confusion (That's What The World Is Today)","status":200,"ts":1542833174796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Selena Gomez & The Scene","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Bell","length":241.91955,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540991795796.0,"sessionId":645,"song":"Naturally","status":200,"ts":1542833315796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 10.0; Windows NT 6.2; WOW64; Trident\/6.0)","userId":"91"} {"artist":"Incubus","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":44,"lastName":"Cuevas","length":289.54077,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Warning","status":200,"ts":1542833420796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Bell","length":240.19546,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540991795796.0,"sessionId":645,"song":"Littlest Things (Live At The Astoria)","status":200,"ts":1542833556796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 10.0; Windows NT 6.2; WOW64; Trident\/6.0)","userId":"91"} {"artist":"Band Of Horses","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":45,"lastName":"Cuevas","length":207.5424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Compliments","status":200,"ts":1542833709796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Stephan Micus","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":46,"lastName":"Cuevas","length":170.94485,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Shen Khar Venakhi","status":200,"ts":1542833916796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Pavement","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":47,"lastName":"Cuevas","length":99.16036,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Mercy:The Laundromat","status":200,"ts":1542834086796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Manolo Otero","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":48,"lastName":"Cuevas","length":253.75302,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Qu\u00c3\u0083\u00c2\u00a9 He De Hacer Para Olvidarte","status":200,"ts":1542834185796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":0,"lastName":"Scott","length":null,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"GET","page":"Home","registration":1540872073796.0,"sessionId":608,"song":null,"status":200,"ts":1542834256796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Randy Crawford","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":49,"lastName":"Cuevas","length":263.33995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Rainy Night In Georgia (Album Version )","status":200,"ts":1542834438796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Parkway Drive","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":50,"lastName":"Cuevas","length":338.99057,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Horizons","status":200,"ts":1542834701796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Radiohead","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":51,"lastName":"Cuevas","length":267.20608,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":816,"song":"Subterranean Homesick Alien","status":200,"ts":1542835039796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":52,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"Logout","registration":1540940782796.0,"sessionId":816,"song":null,"status":307,"ts":1542835040796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":818,"song":null,"status":200,"ts":1542836383796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Kid Rock","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Koch","length":296.95955,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"All Summer Long (Album Version)","status":200,"ts":1542836433796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":53,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":816,"song":null,"status":200,"ts":1542836557796,"userAgent":null,"userId":""} {"artist":"Ray LaMontagne","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Koch","length":235.15383,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Barfly","status":200,"ts":1542836729796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":54,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":816,"song":null,"status":200,"ts":1542836789796,"userAgent":null,"userId":""} {"artist":"CSS","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Koch","length":191.42485,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Meeting Paris Hilton (Album)","status":200,"ts":1542836964796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Koch","length":252.39465,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Live High (Album Version)","status":200,"ts":1542837155796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Elena","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":5,"lastName":"Koch","length":269.58322,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Setanta matins","status":200,"ts":1542837407796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bullet For My Valentine","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":6,"lastName":"Koch","length":258.2722,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Her Voice Resides","status":200,"ts":1542837676796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Deepest Blue","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":7,"lastName":"Koch","length":210.54649,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Deepest Blue","status":200,"ts":1542837934796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Laurie Berkner","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":8,"lastName":"Koch","length":132.67546,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"The Crabs","status":200,"ts":1542838144796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Cake","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":9,"lastName":"Koch","length":190.32771,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Jesus Wrote a Blank Check","status":200,"ts":1542838276796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Lara & Reyes","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":10,"lastName":"Koch","length":277.41995,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"El Castillo","status":200,"ts":1542838466796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"LL Cool J","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":11,"lastName":"Koch","length":248.68526,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Around The Way Girl","status":200,"ts":1542838743796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"El Canto del Loco","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":12,"lastName":"Koch","length":226.0371,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"La Suerte De Mi Vida","status":200,"ts":1542838991796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":13,"lastName":"Koch","length":236.09424,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Canada","status":200,"ts":1542839217796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Kajagoogoo","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":14,"lastName":"Koch","length":223.55546,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Too Shy","status":200,"ts":1542839453796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Sin Animo De Lucro","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":15,"lastName":"Koch","length":212.1922,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Dime Tu","status":200,"ts":1542839676796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Slayer","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":16,"lastName":"Koch","length":233.45587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Ghosts Of War","status":200,"ts":1542839888796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Maine","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":17,"lastName":"Koch","length":209.00526,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"You Left Me","status":200,"ts":1542840121796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Kate Winslet","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":18,"lastName":"Koch","length":106.73587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"What If (Film Version)","status":200,"ts":1542840330796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bertine Zetlitz","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":19,"lastName":"Koch","length":246.30812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Snow On A Hot Day","status":200,"ts":1542840436796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Christopher O'Riley","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":20,"lastName":"Koch","length":337.91955,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"paranoid android","status":200,"ts":1542840682796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Kanye West","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":21,"lastName":"Koch","length":274.41587,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"RoboCop","status":200,"ts":1542841019796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Joy Division","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":22,"lastName":"Koch","length":170.94485,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Digital","status":200,"ts":1542841293796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Al Green","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":23,"lastName":"Koch","length":133.58975,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"I Say A Little Prayer","status":200,"ts":1542841463796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Cage The Elephant","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":24,"lastName":"Koch","length":228.0224,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Back Against The Wall","status":200,"ts":1542841596796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"George Jones","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":25,"lastName":"Koch","length":146.85995,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"She's My Rock","status":200,"ts":1542841824796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Aly & AJ","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":26,"lastName":"Koch","length":150.59546,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Like Whoa","status":200,"ts":1542841970796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Beck","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":27,"lastName":"Koch","length":211.1473,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Girl","status":200,"ts":1542842120796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Decemberists","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":28,"lastName":"Koch","length":313.65179,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Sons & Daughters","status":200,"ts":1542842331796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Rammstein","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":29,"lastName":"Koch","length":256.28689,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"MOSKAU","status":200,"ts":1542842644796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Melody Gardot","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":30,"lastName":"Koch","length":261.32853,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Worrisome Heart","status":200,"ts":1542842900796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"ENUR Feat NATASJA","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":31,"lastName":"Koch","length":230.63465,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Calabria 2007","status":200,"ts":1542843161796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"AFI","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":32,"lastName":"Koch","length":328.72444,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Affliction","status":200,"ts":1542843391796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Edward Sharpe & The Magnetic Zeros","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":33,"lastName":"Koch","length":306.31138,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Home","status":200,"ts":1542843719796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Martina Topley Bird","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":34,"lastName":"Koch","length":177.08363,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Poison","status":200,"ts":1542844025796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Ben Jelen","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":35,"lastName":"Koch","length":226.55955,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Come On (Album Version)","status":200,"ts":1542844202796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":131.3171,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":796,"song":"Kiss With A Fist","status":200,"ts":1542844308796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"3 Doors Down","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":36,"lastName":"Koch","length":237.13914,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Here Without You","status":200,"ts":1542844428796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Jackson Browne","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":37,"lastName":"Koch","length":367.35955,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Sky Blue And Black (LP Version)","status":200,"ts":1542844665796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"}
468.224371
665
0.699157
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Dee Dee Bridgewater","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":38,"lastName":"Koch","length":318.64118,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"La Vie En Rose","status":200,"ts":1542845032796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Tim O'brien","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":39,"lastName":"Koch","length":176.14322,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Think About Last Night","status":200,"ts":1542845350796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Nirvana","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":40,"lastName":"Koch","length":215.11791,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Love Buzz","status":200,"ts":1542845526796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Weezer","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":41,"lastName":"Koch","length":479.32036,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Only In Dreams","status":200,"ts":1542845741796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Nightwish","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":42,"lastName":"Koch","length":286.1971,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"She Is My Sin","status":200,"ts":1542846220796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"California Swag District","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":43,"lastName":"Koch","length":239.17669,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Teach Me How To Dougie","status":200,"ts":1542846506796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Miike Snow","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":44,"lastName":"Koch","length":385.35791,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Silvia","status":200,"ts":1542846745796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Katy Perry","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":45,"lastName":"Koch","length":179.40853,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"I Kissed A Girl","status":200,"ts":1542847130796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Sikth","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":46,"lastName":"Koch","length":250.53995,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Peep Show","status":200,"ts":1542847309796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":47,"lastName":"Koch","length":199.88853,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Not Fair","status":200,"ts":1542847559796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Presidents of the United States of America","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":48,"lastName":"Koch","length":495.77751,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Lump","status":200,"ts":1542847758796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Wordsworth","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":49,"lastName":"Koch","length":253.1522,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Right Now (Produced by Ayatollah)","status":200,"ts":1542848253796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Rihanna","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":50,"lastName":"Koch","length":229.04118,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Take A Bow","status":200,"ts":1542848506796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Tomas Bodin","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":51,"lastName":"Koch","length":396.53832,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Back To The African Garden","status":200,"ts":1542848735796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":52,"lastName":"Koch","length":326.86975,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"My Humps","status":200,"ts":1542849131796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Carolina Liar","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":53,"lastName":"Koch","length":240.45669,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Show Me What I'm Looking For (Album Version)","status":200,"ts":1542849457796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Kansas","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":54,"lastName":"Koch","length":202.29179,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Dust in The Wind","status":200,"ts":1542849697796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Onar","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":55,"lastName":"Koch","length":306.6771,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Xehasmeni Melodia","status":200,"ts":1542849899796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Live","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":56,"lastName":"Koch","length":286.98077,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Lakini's Juice","status":200,"ts":1542850205796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Abstract Rude","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":57,"lastName":"Koch","length":196.85832,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Nuff Fire","status":200,"ts":1542850491796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Johnny Horton","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":58,"lastName":"Koch","length":131.81342,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Mean Mean Son Of A Gun","status":200,"ts":1542850687796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Men They Couldn't Hang","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":59,"lastName":"Koch","length":251.14077,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Ironmasters","status":200,"ts":1542850818796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Rilo Kiley","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":60,"lastName":"Koch","length":234.03057,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"The Absence Of God (Album Version)","status":200,"ts":1542851069796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Shwayze","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":61,"lastName":"Koch","length":201.63873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Lost My Mind","status":200,"ts":1542851303796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bram Vermeulen","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":62,"lastName":"Koch","length":251.42812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Mamma","status":200,"ts":1542851504796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Death Cab for Cutie","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":63,"lastName":"Koch","length":189.3873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"I Will Follow You into the Dark (Album Version)","status":200,"ts":1542851755796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":64,"lastName":"Koch","length":239.3073,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"You're The One","status":200,"ts":1542851944796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Jadakiss \/ Ghostface Killah \/ Raekwon","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":65,"lastName":"Koch","length":173.76608,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Cartel Gathering","status":200,"ts":1542852183796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Rosana","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":66,"lastName":"Koch","length":256.31302,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Si tu no estas","status":200,"ts":1542852356796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":0,"lastName":"Summers","length":null,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"GET","page":"Home","registration":1540344794796.0,"sessionId":775,"song":null,"status":200,"ts":1542852417796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":null,"auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":1,"lastName":"Summers","length":null,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"GET","page":"Upgrade","registration":1540344794796.0,"sessionId":775,"song":null,"status":200,"ts":1542852451796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":null,"auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":2,"lastName":"Summers","length":null,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"GET","page":"Home","registration":1540344794796.0,"sessionId":775,"song":null,"status":200,"ts":1542852453796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"The Killers","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":67,"lastName":"Koch","length":230.39955,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"The Ballad of Michael Valentine","status":200,"ts":1542852612796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":68,"lastName":"Koch","length":195.94404,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Sincerit\u00c3\u0083\u00c2\u00a9 Et Jalousie","status":200,"ts":1542852842796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Enya","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":69,"lastName":"Koch","length":289.802,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"China Roses","status":200,"ts":1542853037796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Aya RL","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":70,"lastName":"Koch","length":225.43628,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":818,"song":"Jazz","status":200,"ts":1542853326796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":71,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"Logout","registration":1541048010796.0,"sessionId":818,"song":null,"status":307,"ts":1542853327796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":72,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":818,"song":null,"status":200,"ts":1542853339796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":73,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"About","registration":null,"sessionId":818,"song":null,"status":200,"ts":1542853580796,"userAgent":null,"userId":""} {"artist":"Clor","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":227.68281,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":820,"song":"Love + Pain","status":200,"ts":1542855728796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Alejandro Fernandez","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":262.84363,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":820,"song":"Solitario Y Solo","status":200,"ts":1542855955796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Yonder Mountain String Band","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":152.18893,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":820,"song":"Midwest Gospel Radio","status":200,"ts":1542856217796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"K'Naan","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":220.49914,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":824,"song":"Wavin' Flag","status":200,"ts":1542871300796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Cradle Of Filth","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":453.09342,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Her Ghost In The Fog","status":200,"ts":1542883866796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Amanda Marshall","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":274.28526,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Let It Rain","status":200,"ts":1542884319796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Rammstein","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":272.40444,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Sonne","status":200,"ts":1542884593796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":167.6273,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"If You Want To Sing Out_ Sing Out","status":200,"ts":1542884865796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Emma Shapplin","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":267.62404,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Spente Le Stelle","status":200,"ts":1542885032796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":209.52771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Float On","status":200,"ts":1542885299796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Flaco Jimenez","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":155.81995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"En El Cielo No Hay Cerveza (In Heaven There Is No Beer)","status":200,"ts":1542885508796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":209.52771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Float On","status":200,"ts":1542885663796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Cedric Gervais feat. Second Sun","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":230.32118,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Pills (Radio Edit) (Radio Edit)","status":200,"ts":1542885872796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Sheena Easton","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":239.62077,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Strut (1993 Digital Remaster)","status":200,"ts":1542886102796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Everything But The Girl","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":218.74893,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"My Baby Don't Love Me","status":200,"ts":1542886341796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":219.66322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1542886559796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"BoDeans","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":12,"lastName":"Harrell","length":354.01098,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Naked (Live)","status":200,"ts":1542886778796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":13,"lastName":"Harrell","length":208.14322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Apologize","status":200,"ts":1542887132796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Miley Cyrus","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":14,"lastName":"Harrell","length":194.45506,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Full Circle","status":200,"ts":1542887340796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":15,"lastName":"Harrell","length":139.12771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Don't Panic","status":200,"ts":1542887534796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Atreyu","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":16,"lastName":"Harrell","length":308.37506,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"You Were The King_ Now You're Unconscious (Album Version)","status":200,"ts":1542887673796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bruce Springsteen","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":17,"lastName":"Harrell","length":270.54975,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Born To Run","status":200,"ts":1542887981796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":18,"lastName":"Harrell","length":348.57751,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Undo","status":200,"ts":1542888251796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Big Shug","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":19,"lastName":"Harrell","length":140.56444,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"It Just Don't Stop","status":200,"ts":1542888599796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Wallflowers","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":20,"lastName":"Harrell","length":315.24526,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Be Your Own Girl","status":200,"ts":1542888739796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Chris Brown","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":21,"lastName":"Harrell","length":203.80689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Ain't No Way (You Won't Love Me)","status":200,"ts":1542889054796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Charly Garc\u00c3\u0083\u00c2\u00ada","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":22,"lastName":"Harrell","length":231.73179,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Filosofia Barata Y Zapatos De Goma","status":200,"ts":1542889257796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"N.W.A ft. Eazy-E","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":23,"lastName":"Harrell","length":338.18077,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Boyz-N-The-Hood","status":200,"ts":1542889488796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"The Mighty Mighty Bosstones","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":24,"lastName":"Harrell","length":158.87628,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"1-2-8","status":200,"ts":1542889826796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":25,"lastName":"Harrell","length":211.722,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Unite (2009 Digital Remaster)","status":200,"ts":1542889984796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Yuksek","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":26,"lastName":"Harrell","length":218.95791,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Take A Ride","status":200,"ts":1542890195796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Fernando Ubiergo","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":27,"lastName":"Harrell","length":218.74893,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Cuando Agosto Era 21","status":200,"ts":1542890413796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Phoenix","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":28,"lastName":"Harrell","length":192.86159,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":828,"song":"Napoleon Says","status":200,"ts":1542890631796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Radney Foster","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":288.96608,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":790,"song":"Sweet And Wild","status":200,"ts":1542892592796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Neneh Cherry","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":232.202,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":790,"song":"Manchild","status":200,"ts":1542892880796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Hooligans","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":189.98812,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":785,"song":"Szex & KV","status":200,"ts":1542892881796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"Kid Cudi \/ MGMT \/ Ratatat","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":295.67955,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":786,"song":"Pursuit Of Happiness (nightmare)","status":200,"ts":1542895455796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Foals","auth":"Logged In","firstName":"Morris","gender":"M","itemInSession":0,"lastName":"Gilmore","length":316.89098,"level":"free","location":"Raleigh, NC","method":"PUT","page":"NextSong","registration":1540971561796.0,"sessionId":351,"song":"Blue Blood","status":200,"ts":1542898727796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_1 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D201 Safari\/9537.53\"","userId":"23"} {"artist":"'N Sync\/Phil Collins","auth":"Logged In","firstName":"Morris","gender":"M","itemInSession":1,"lastName":"Gilmore","length":143.64689,"level":"free","location":"Raleigh, NC","method":"PUT","page":"NextSong","registration":1540971561796.0,"sessionId":351,"song":"Trashin' The Camp (Phil And 'N Sync Version)","status":200,"ts":1542899043796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_1 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D201 Safari\/9537.53\"","userId":"23"} {"artist":"Kristian Stanfill","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":287.50322,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":838,"song":"I Need You","status":200,"ts":1542899108796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Enrique Iglesias","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":241.42322,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":838,"song":"Tired Of Being Sorry","status":200,"ts":1542899395796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Michael Cretu","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Fox","length":301.06077,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":838,"song":"The Invisible Man","status":200,"ts":1542899636796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Tommy Emmanuel","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Fox","length":168.14975,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":838,"song":"Windy & Warm","status":200,"ts":1542899937796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":4,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"Logout","registration":1541033612796.0,"sessionId":838,"song":null,"status":307,"ts":1542899938796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":5,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":838,"song":null,"status":200,"ts":1542899950796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":6,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":838,"song":null,"status":307,"ts":1542899951796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":7,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":838,"song":null,"status":200,"ts":1542899973796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Rodriguez","length":null,"level":"free","location":"Los Angeles-Long Beach-Anaheim, CA","method":"GET","page":"Home","registration":1540992715796.0,"sessionId":523,"song":null,"status":200,"ts":1542902321796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"68"} {"artist":"Cherise","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":0,"lastName":"White","length":229.69424,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":772,"song":"No Good 4 You","status":200,"ts":1542907100796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":835,"song":null,"status":200,"ts":1542909562796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Anna Waronker","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":0,"lastName":"Duffy","length":189.6224,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":662,"song":"Nothing Personal","status":200,"ts":1542910267796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"King Chang\u00c3\u0083\u00c2\u00b3","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":340.74077,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":763,"song":"Confesi\u00c3\u0083\u00c2\u00b3n","status":200,"ts":1542917905796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Gang Of Four","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":1,"lastName":"Owens","length":193.14893,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":763,"song":"I Found That Essence Rare","status":200,"ts":1542918245796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Line Renaud","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":2,"lastName":"Owens","length":176.16934,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":763,"song":"Le Soir","status":200,"ts":1542918438796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":823,"song":null,"status":307,"ts":1542923831796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":823,"song":null,"status":200,"ts":1542923842796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"the bird and the bee","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":198.1122,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":823,"song":"Last Day Of Our Love","status":200,"ts":1542924694796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":831,"song":null,"status":200,"ts":1542930628796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":831,"song":null,"status":200,"ts":1542931106796,"userAgent":null,"userId":""}
470.244898
543
0.698014
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Great Lake Swimmers","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":215.11791,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":815,"song":"Your Rocky Spine","status":200,"ts":1542931645796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Soziedad Alkoholika","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":1,"lastName":"Arellano","length":204.7473,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":815,"song":"Va Bien","status":200,"ts":1542931860796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Franz Ferdinand","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":2,"lastName":"Arellano","length":172.01587,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":815,"song":"Eleanor Put Your Boots On","status":200,"ts":1542932064796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":3,"lastName":"Arellano","length":209.52771,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":815,"song":"Float On","status":200,"ts":1542932236796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Adam Lambert","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":4,"lastName":"Arellano","length":266.44853,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":815,"song":"Aftermath","status":200,"ts":1542932445796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Parni Valjak","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":5,"lastName":"Arellano","length":259.83955,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":815,"song":"Dok si pored mene","status":200,"ts":1542932711796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":6,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"GET","page":"Home","registration":1540006905796.0,"sessionId":815,"song":null,"status":200,"ts":1542932752796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Flaw","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":7,"lastName":"Arellano","length":265.89995,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":815,"song":"Not Enough","status":200,"ts":1542932970796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":8,"lastName":"Arellano","length":250.14812,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":815,"song":"Everlong","status":200,"ts":1542933235796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"\u00c3\u0083\u00c2\u0081ngeles del Infierno","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":9,"lastName":"Arellano","length":267.25832,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":815,"song":"Si T\u00c3\u0083\u00c2\u00ba No Est\u00c3\u0083\u00c2\u00a1s Aqu\u00c3\u0083\u00c2\u00ad","status":200,"ts":1542933485796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Smash Mouth","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":10,"lastName":"Arellano","length":216.39791,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":815,"song":"All Star","status":200,"ts":1542933752796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":null,"auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":null,"level":"free","location":"Santa Rosa, CA","method":"GET","page":"Home","registration":1540880381796.0,"sessionId":839,"song":null,"status":200,"ts":1542933838796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9 feat. Jay-Z","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":1,"lastName":"Johnson","length":235.93751,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":839,"song":"Crazy In Love","status":200,"ts":1542933907796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"Aaliyah","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":2,"lastName":"Johnson","length":228.28363,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":839,"song":"More Than A Woman","status":200,"ts":1542934142796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":0,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"Home","registration":1540907087796.0,"sessionId":821,"song":null,"status":200,"ts":1542936763796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Coldplay","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":1,"lastName":"Benson","length":268.38159,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":821,"song":"Yellow","status":200,"ts":1542936896796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Martin Solveig","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":2,"lastName":"Benson","length":246.282,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":821,"song":"Something About You","status":200,"ts":1542937164796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":3,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"Logout","registration":1540907087796.0,"sessionId":821,"song":null,"status":307,"ts":1542937165796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":821,"song":null,"status":200,"ts":1542937172796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":5,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"About","registration":null,"sessionId":821,"song":null,"status":200,"ts":1542937234796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":6,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":821,"song":null,"status":307,"ts":1542937235796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":7,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"Home","registration":1540907087796.0,"sessionId":821,"song":null,"status":200,"ts":1542937294796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Simple Minds","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":240.03873,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":845,"song":"Glittering Prize","status":200,"ts":1542940536796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":284.05506,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":845,"song":"Don't Cry (Original)","status":200,"ts":1542940776796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Erin Bode","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":0,"lastName":"George","length":252.05506,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":617,"song":"Here_ There And Everywhere","status":200,"ts":1542944904796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Blue Oyster Cult","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":1,"lastName":"George","length":322.42893,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":617,"song":"Buck's Boogie","status":200,"ts":1542945156796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Little Boots","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":2,"lastName":"George","length":195.94404,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":617,"song":"Meddle","status":200,"ts":1542945478796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"FM Static","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":3,"lastName":"George","length":218.27873,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":617,"song":"Tonight","status":200,"ts":1542945673796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Dead Kennedys","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":4,"lastName":"George","length":90.40934,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":617,"song":"Terminal Preppie","status":200,"ts":1542945891796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Jim Jones & Ron Browz featuring Juelz Santana","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":5,"lastName":"George","length":215.97995,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":617,"song":"Pop Champagne","status":200,"ts":1542945981796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Dr. Dre \/ Eminem \/ Alvin Joiner","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":6,"lastName":"George","length":244.21832,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":617,"song":"What's The Difference","status":200,"ts":1542946196796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Cinematic Orchestra","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":373.9424,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":850,"song":"To Build A Home","status":200,"ts":1542952618796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Cradle Of Filth","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":1,"lastName":"Arellano","length":355.94404,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":850,"song":"Tonight In Flames (Album Version)","status":200,"ts":1542952991796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Disturbed","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":224.86159,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":847,"song":"Numb (Album Version)","status":200,"ts":1542953278796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Viola","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":2,"lastName":"Arellano","length":260.25751,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":850,"song":"Nostalgia Amnesia","status":200,"ts":1542953346796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":1,"lastName":"Owens","length":220.89098,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":847,"song":"Somebody To Love","status":200,"ts":1542953502796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":null,"auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":0,"lastName":"Scott","length":null,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"GET","page":"Home","registration":1540872073796.0,"sessionId":830,"song":null,"status":200,"ts":1542953700796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":2,"lastName":"Owens","length":239.3073,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":847,"song":"You're The One","status":200,"ts":1542953722796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":null,"auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Home","registration":1541044398796.0,"sessionId":791,"song":null,"status":200,"ts":1542954495796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Ivy","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":1,"lastName":"Simpson","length":264.61995,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":791,"song":"Edge Of The Ocean","status":200,"ts":1542954496796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Jill Barber","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":199.52281,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":836,"song":"Two Brown Eyes","status":200,"ts":1542956736796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Bootsy Collins","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":0,"lastName":"Williams","length":411.42812,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":826,"song":"Stretchin' Out (In A Rubber Band) (LP Version)","status":200,"ts":1542958442796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Toy-Box","auth":"Logged In","firstName":"Cienna","gender":"F","itemInSession":0,"lastName":"Freeman","length":197.79873,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540998613796.0,"sessionId":131,"song":"Eenie_ Meenie_ Miney_ Mo","status":200,"ts":1542959440796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"56"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":755,"song":null,"status":307,"ts":1542959472796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Noah","gender":"M","itemInSession":1,"lastName":"Chavez","length":null,"level":"free","location":"Ogden-Clearfield, UT","method":"GET","page":"Home","registration":1540970748796.0,"sessionId":755,"song":null,"status":200,"ts":1542959473796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"94"} {"artist":"The Libertines","auth":"Logged In","firstName":"Noah","gender":"M","itemInSession":2,"lastName":"Chavez","length":203.72853,"level":"free","location":"Ogden-Clearfield, UT","method":"PUT","page":"NextSong","registration":1540970748796.0,"sessionId":755,"song":"Can't Stand Me Now","status":200,"ts":1542959497796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"94"} {"artist":"Beirut","auth":"Logged In","firstName":"Cienna","gender":"F","itemInSession":1,"lastName":"Freeman","length":142.31465,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540998613796.0,"sessionId":131,"song":"The Penalty","status":200,"ts":1542959637796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"56"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Noah","gender":"M","itemInSession":3,"lastName":"Chavez","length":154.14812,"level":"free","location":"Ogden-Clearfield, UT","method":"PUT","page":"NextSong","registration":1540970748796.0,"sessionId":755,"song":"Love Is A Losing Game","status":200,"ts":1542959700796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"94"} {"artist":null,"auth":"Logged In","firstName":"Connar","gender":"M","itemInSession":0,"lastName":"Moreno","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540823606796.0,"sessionId":752,"song":null,"status":200,"ts":1542963621796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10) AppleWebKit\/538.46 (KHTML, like Gecko) Version\/8.0 Safari\/538.46\"","userId":"62"} {"artist":null,"auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Home","registration":1540266185796.0,"sessionId":788,"song":null,"status":200,"ts":1542963711796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":null,"auth":"Logged In","firstName":"Jordyn","gender":"F","itemInSession":0,"lastName":"Powell","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Home","registration":1540828399796.0,"sessionId":357,"song":null,"status":200,"ts":1542969532796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"98"} {"artist":"Slipknot","auth":"Logged In","firstName":"Jordyn","gender":"F","itemInSession":1,"lastName":"Powell","length":278.59546,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1540828399796.0,"sessionId":357,"song":"Before I Forget (Album Version)","status":200,"ts":1542969549796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"98"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Jordyn","gender":"F","itemInSession":2,"lastName":"Powell","length":183.61424,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1540828399796.0,"sessionId":357,"song":"One More Sad Song","status":200,"ts":1542969827796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"98"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Andrea","gender":"F","itemInSession":0,"lastName":"Butler","length":406.17751,"level":"free","location":"Pensacola-Ferry Pass-Brent, FL","method":"PUT","page":"NextSong","registration":1541098488796.0,"sessionId":745,"song":"Paradise City","status":200,"ts":1542970639796,"userAgent":"Mozilla\/5.0 (X11; Linux x86_64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"90"} {"artist":"Harmonia","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":655.77751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Sehr kosmisch","status":200,"ts":1542970955796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Roky Erickson","auth":"Logged In","firstName":"Andrea","gender":"F","itemInSession":1,"lastName":"Butler","length":248.0322,"level":"free","location":"Pensacola-Ferry Pass-Brent, FL","method":"PUT","page":"NextSong","registration":1541098488796.0,"sessionId":745,"song":"Cold night for alligators","status":200,"ts":1542971045796,"userAgent":"Mozilla\/5.0 (X11; Linux x86_64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"90"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":58.90567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Interlude (Milo)","status":200,"ts":1542971610796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Velour 100","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":202.29179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Clouds (Of Color Bright Album Version)","status":200,"ts":1542971668796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Soundgarden","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":290.11546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Burden In My Hand","status":200,"ts":1542971870796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Shinedown","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":229.98159,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Devour (Album Version)","status":200,"ts":1542972160796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Benassi Bros.","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":348.60363,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Turn Me Up (Sfaction Version \/ Feat. Sandy)","status":200,"ts":1542972389796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":211.01669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Tighten Up","status":200,"ts":1542972737796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":237.03465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Jump Then Fall","status":200,"ts":1542972948796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":0,"lastName":"George","length":null,"level":"paid","location":"Birmingham-Hoover, AL","method":"GET","page":"Home","registration":1541020249796.0,"sessionId":854,"song":null,"status":200,"ts":1542973056796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Company Flow","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":1,"lastName":"George","length":347.53261,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"Definitive","status":200,"ts":1542973064796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Belanova","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":187.53261,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Me Pregunto","status":200,"ts":1542973185796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Hinder","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":262.05995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Lips Of An Angel","status":200,"ts":1542973372796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Armin van Buuren","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":2,"lastName":"George","length":425.9522,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"Intricacy","status":200,"ts":1542973411796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":848,"song":null,"status":200,"ts":1542973419796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Lauryn Hill","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":326.53016,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Ex-Factor","status":200,"ts":1542973634796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":0,"lastName":"White","length":null,"level":"free","location":"Lubbock, TX","method":"GET","page":"Home","registration":1540708070796.0,"sessionId":844,"song":null,"status":200,"ts":1542973759796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"12 Stones","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":3,"lastName":"George","length":225.98485,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"The Way I Feel (Not Our Master)","status":200,"ts":1542973836796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"WILL B","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":525.26975,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Upgrade","status":200,"ts":1542973960796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mikromusic","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":4,"lastName":"George","length":289.17506,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"Moje Mieszkanie","status":200,"ts":1542974061796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Kajagoogoo","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":5,"lastName":"George","length":223.55546,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"Too Shy","status":200,"ts":1542974350796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Pearl Jam","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":219.32363,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Can't Keep","status":200,"ts":1542974485796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Marilyn Manson","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":6,"lastName":"George","length":305.76281,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"I Don't Like The Drugs (But The Drugs Like Me)","status":200,"ts":1542974573796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Darkness","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":209.3971,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Growing On Me","status":200,"ts":1542974704796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":7,"lastName":"George","length":290.48118,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"Rabbit Heart (Raise It Up)","status":200,"ts":1542974878796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Rilo Kiley","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":205.26975,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"More Adventurous (Album Version)","status":200,"ts":1542974913796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"David Banner \/ Chris Brown \/ Yung Joc","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":224.54812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Get Like Me","status":200,"ts":1542975118796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Tracy Nelson","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":8,"lastName":"George","length":272.74404,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"Cry On (Album Version)","status":200,"ts":1542975168796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Mogwai","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":327.23546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Kids Will Be Skeletons","status":200,"ts":1542975342796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Peter Tosh","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":9,"lastName":"George","length":790.36036,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"Rastafari Is","status":200,"ts":1542975440796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Bernard Fanning","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":18,"lastName":"Levine","length":151.09179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Wish You Well","status":200,"ts":1542975669796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Origin Unknown","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":19,"lastName":"Levine","length":273.44934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Valley of the Shadows","status":200,"ts":1542975820796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kristofer \u00c3\u0083\u00c2\u0085str\u00c3\u0083\u00c2\u00b6m","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":20,"lastName":"Levine","length":341.26322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Not Cool Again","status":200,"ts":1542976093796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kiuas","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":10,"lastName":"George","length":265.24689,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"The New Chapter","status":200,"ts":1542976230796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Cage The Elephant","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":21,"lastName":"Levine","length":228.0224,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Back Against The Wall","status":200,"ts":1542976434796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Stephen Fretwell","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":11,"lastName":"George","length":215.69261,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"Emily","status":200,"ts":1542976495796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Randy Crawford","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":22,"lastName":"Levine","length":270.75873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Almaz","status":200,"ts":1542976662796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Justice","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":12,"lastName":"George","length":236.12036,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"DVNO","status":200,"ts":1542976710796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":23,"lastName":"Levine","length":252.21179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1542976932796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kaiser Chiefs","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":13,"lastName":"George","length":221.07383,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"Try Your Best","status":200,"ts":1542976946796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Krokus","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":14,"lastName":"George","length":254.51057,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"Out Of Control","status":200,"ts":1542977167796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Bloodhound Gang","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":24,"lastName":"Levine","length":261.79873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"The Bad Touch","status":200,"ts":1542977184796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Naughty By Nature","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":15,"lastName":"George","length":269.68771,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"O.P.P.","status":200,"ts":1542977421796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Mercury Program","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":25,"lastName":"Levine","length":439.50975,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Fragile or Possibly Extinct","status":200,"ts":1542977445796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Filterfunk","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":173.03465,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":760,"song":"S.O.S. (Message In A Bottle) (Hi_Tack Radio Edit)","status":200,"ts":1542977496796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Genesis","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":265.97832,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":853,"song":"That's All (2007 Digital Remaster)","status":200,"ts":1542977553796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Selena Gomez & The Scene","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":172.61669,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":760,"song":"Stop & Erase","status":200,"ts":1542977669796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Public Image Ltd","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":16,"lastName":"George","length":550.68689,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"Theme","status":200,"ts":1542977690796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Johnny Winter","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":26,"lastName":"Levine","length":223.81669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":848,"song":"Still Alive And Well","status":200,"ts":1542977884796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":27,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"Logout","registration":1540794356796.0,"sessionId":848,"song":null,"status":307,"ts":1542977885796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":null,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1541032432796.0,"sessionId":857,"song":null,"status":200,"ts":1542977904796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":28,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":848,"song":null,"status":200,"ts":1542978179796,"userAgent":null,"userId":""} {"artist":"Gordon Lightfoot","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":17,"lastName":"George","length":179.9571,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":854,"song":"Long Thin Dawn","status":200,"ts":1542978240796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":29,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"About","registration":null,"sessionId":848,"song":null,"status":200,"ts":1542979357796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":30,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":848,"song":null,"status":200,"ts":1542979839796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":868,"song":null,"status":200,"ts":1542983010796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"The Courteeners","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":225.48853,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":868,"song":"Take Over The World","status":200,"ts":1542983106796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Daughtry","auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":0,"lastName":"Garrison","length":201.63873,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"PUT","page":"NextSong","registration":1540832693796.0,"sessionId":798,"song":"Gone","status":200,"ts":1542983270796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":null,"auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":1,"lastName":"Garrison","length":null,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"PUT","page":"Logout","registration":1540832693796.0,"sessionId":798,"song":null,"status":307,"ts":1542983271796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":798,"song":null,"status":200,"ts":1542983307796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":798,"song":null,"status":307,"ts":1542983308796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":4,"lastName":"Garrison","length":null,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"GET","page":"Home","registration":1540832693796.0,"sessionId":798,"song":null,"status":200,"ts":1542983519796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":0,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1540871783796.0,"sessionId":691,"song":null,"status":200,"ts":1542983933796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Sugarman 3","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":1,"lastName":"Watkins","length":177.44934,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Honey Wagon","status":200,"ts":1542983934796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Shawn McDonald","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":0,"lastName":"Larson","length":358.89587,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":765,"song":"Lovely","status":200,"ts":1542984111796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"El Cuarteto De Nos","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":2,"lastName":"Watkins","length":241.44934,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Invierno Del 92","status":200,"ts":1542984111796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Chromeo","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":3,"lastName":"Watkins","length":274.31138,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Rage!","status":200,"ts":1542984352796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Aaliyah","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":1,"lastName":"Larson","length":266.50077,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":765,"song":"Are You That Somebody? ( LP Version )","status":200,"ts":1542984469796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"Rick James","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":4,"lastName":"Watkins","length":209.97179,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Stone City Band_ Hi!","status":200,"ts":1542984626796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"John Mayer","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":5,"lastName":"Watkins","length":548.88444,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Clarity","status":200,"ts":1542984835796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540492941796.0,"sessionId":748,"song":null,"status":200,"ts":1542985227796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Ticanaf","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":1,"lastName":"Gonzalez","length":2594.87302,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":748,"song":"The Thousand Names of Lord Shiva (Part 1)","status":200,"ts":1542985259796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Symphony X","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":6,"lastName":"Watkins","length":98.21995,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Prelude","status":200,"ts":1542985383796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":7,"lastName":"Watkins","length":252.81261,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Peace Train","status":200,"ts":1542985481796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Kills","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":8,"lastName":"Watkins","length":203.38893,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Last Day Of Magic","status":200,"ts":1542985733796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"De-Phazz","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":9,"lastName":"Watkins","length":177.50159,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Better Now","status":200,"ts":1542985936796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Tree63","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":10,"lastName":"Watkins","length":137.79546,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"You Only (Acoustic Version)","status":200,"ts":1542986113796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":0,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":809,"song":null,"status":200,"ts":1542986148796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":1,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"Logout","registration":1541057188796.0,"sessionId":809,"song":null,"status":307,"ts":1542986149796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":809,"song":null,"status":200,"ts":1542986228796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":809,"song":null,"status":307,"ts":1542986229796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":4,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":809,"song":null,"status":200,"ts":1542986241796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":5,"lastName":"Griffin","length":238.8371,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":809,"song":"Happy Alone","status":200,"ts":1542986243796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Kings Of Convenience","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":11,"lastName":"Watkins","length":227.44771,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Sorry Or Please","status":200,"ts":1542986250796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Metallica","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":12,"lastName":"Watkins","length":415.16363,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Fade To Black","status":200,"ts":1542986477796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Dimmu Borgir","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":6,"lastName":"Griffin","length":385.41016,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":809,"song":"A succubus in rapture","status":200,"ts":1542986481796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Panda","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":7,"lastName":"Griffin","length":120.47628,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":809,"song":"Amnist\u00c3\u0083\u00c2\u00ada","status":200,"ts":1542986866796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Jackson Do Pandeiro","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":13,"lastName":"Watkins","length":157.51791,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"O Canto Da Ema","status":200,"ts":1542986892796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Kid Cudi","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":0,"lastName":"Williams","length":227.34322,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":860,"song":"Up Up & Away","status":200,"ts":1542986963796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Kate Voegele","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":8,"lastName":"Griffin","length":218.01751,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":809,"song":"You Can't Break A Broken Heart","status":200,"ts":1542986986796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bill Withers","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":14,"lastName":"Watkins","length":383.73832,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Make Love To Your Mind","status":200,"ts":1542987049796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":15,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Error","registration":1540871783796.0,"sessionId":691,"song":null,"status":404,"ts":1542987059796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Matt Redman","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":303.46404,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":864,"song":"Blessed Be Your Name","status":200,"ts":1542987097796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Stacie Orrico","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":1,"lastName":"Williams","length":225.35791,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":860,"song":"Stuck (Album Version)","status":200,"ts":1542987190796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Shadows Fall","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":9,"lastName":"Griffin","length":220.3424,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":809,"song":"War","status":200,"ts":1542987204796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Killers","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":16,"lastName":"Watkins","length":246.80444,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Read My Mind","status":200,"ts":1542987432796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Atmosphere","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":17,"lastName":"Watkins","length":257.38404,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Trying To Find A Balance","status":200,"ts":1542987678796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"La Ley","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":0,"lastName":"Benson","length":271.69914,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"D\u00c3\u0083\u00c2\u00ada cero","status":200,"ts":1542987869796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Jackson C. Frank","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":18,"lastName":"Watkins","length":164.04853,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Halloween Is Black As Night","status":200,"ts":1542987935796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Juno Reactor","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":19,"lastName":"Watkins","length":365.40036,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Masters Of Universe","status":200,"ts":1542988099796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Kid Cudi","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":1,"lastName":"Benson","length":220.89098,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Sky Might Fall","status":200,"ts":1542988140796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Luza","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":76.66893,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Outro","status":200,"ts":1542988354796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Mayday Parade","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":2,"lastName":"Benson","length":247.92771,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Take This To Heart (Album)","status":200,"ts":1542988360796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Tokio Hotel","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":220.3424,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Totgeliebt","status":200,"ts":1542988430796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":840,"song":null,"status":200,"ts":1542988461796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Madonna","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":20,"lastName":"Watkins","length":260.75383,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Beautiful Stranger","status":200,"ts":1542988464796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Sneaker Pimps","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":3,"lastName":"Benson","length":246.22975,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Walking Zero","status":200,"ts":1542988607796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Dido","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":217.83465,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Thank You","status":200,"ts":1542988650796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Static-X","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":21,"lastName":"Watkins","length":134.13832,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Monster (Album Version)","status":200,"ts":1542988724796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":732,"song":null,"status":200,"ts":1542988794796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":732,"song":null,"status":200,"ts":1542988809796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":732,"song":null,"status":200,"ts":1542988823796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":732,"song":null,"status":307,"ts":1542988824796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Makinley","gender":"F","itemInSession":4,"lastName":"Jones","length":null,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541091973796.0,"sessionId":732,"song":null,"status":200,"ts":1542988829796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"17"} {"artist":"Golden Smog","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":4,"lastName":"Benson","length":222.69342,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Ill Fated","status":200,"ts":1542988853796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"504 Boyz","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":22,"lastName":"Watkins","length":269.03465,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Tight Whips","status":200,"ts":1542988858796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"The Ruts","auth":"Logged In","firstName":"Makinley","gender":"F","itemInSession":5,"lastName":"Jones","length":338.96444,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541091973796.0,"sessionId":732,"song":"West One (Shine On Me)","status":200,"ts":1542988859796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"17"} {"artist":"Beanfield","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":3,"lastName":"Rodriguez","length":366.0273,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Human Patterns","status":200,"ts":1542988867796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":5,"lastName":"Benson","length":219.66322,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1542989075796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Pepper","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":23,"lastName":"Watkins","length":235.31057,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Dry Spell (LP Version)","status":200,"ts":1542989127796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":872,"song":null,"status":200,"ts":1542989141796,"userAgent":null,"userId":""} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":4,"lastName":"Rodriguez","length":206.47138,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Hardest Of Hearts","status":200,"ts":1542989233796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":5,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"Logout","registration":1540511766796.0,"sessionId":812,"song":null,"status":307,"ts":1542989234796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Coldplay","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":6,"lastName":"Benson","length":294.1122,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Fix You","status":200,"ts":1542989294796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":6,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":812,"song":null,"status":200,"ts":1542989315796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":7,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":812,"song":null,"status":307,"ts":1542989316796,"userAgent":null,"userId":""} {"artist":"Coldplay","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":24,"lastName":"Watkins","length":228.77995,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"In My Place","status":200,"ts":1542989362796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":8,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":812,"song":null,"status":200,"ts":1542989505796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Boys Like Girls featuring Taylor Swift","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":7,"lastName":"Benson","length":242.83383,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Two Is Better Than One","status":200,"ts":1542989588796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Everclear","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":25,"lastName":"Watkins","length":222.61506,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Summerland","status":200,"ts":1542989590796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":8,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"Home","registration":1540907087796.0,"sessionId":852,"song":null,"status":200,"ts":1542989595796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Erasure","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":9,"lastName":"Rodriguez","length":242.28526,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Always (7'' Mix)","status":200,"ts":1542989810796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":10,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Downgrade","registration":1540511766796.0,"sessionId":812,"song":null,"status":200,"ts":1542989810796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Two Door Cinema Club","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":26,"lastName":"Watkins","length":209.73669,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"This Is The Life","status":200,"ts":1542989812796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Serj Tankian","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":9,"lastName":"Benson","length":281.46893,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Saving Us (Album Version)","status":200,"ts":1542989830796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":11,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":812,"song":null,"status":200,"ts":1542989839796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Mamonas Assassinas","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":27,"lastName":"Watkins","length":156.682,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Jumento Celestino","status":200,"ts":1542990021796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Sara Groves","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":12,"lastName":"Rodriguez","length":287.45098,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"What Do I Know","status":200,"ts":1542990052796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Antonio Carlos Jobim","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":10,"lastName":"Benson","length":151.77098,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Ela E Carioca","status":200,"ts":1542990111796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Jorge Drexler","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":28,"lastName":"Watkins","length":212.55791,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"La Huella De Tu Mirada","status":200,"ts":1542990177796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Antony & The Johnsons","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":11,"lastName":"Benson","length":100.51873,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"What Can I Do?","status":200,"ts":1542990262796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"The Fugees","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":13,"lastName":"Rodriguez","length":281.20771,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Ready Or Not","status":200,"ts":1542990339796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Matt Costa","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":12,"lastName":"Benson","length":215.17016,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Behind The Moon","status":200,"ts":1542990362796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Limp Bizkit","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":29,"lastName":"Watkins","length":270.49751,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Behind Blue Eyes","status":200,"ts":1542990389796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":13,"lastName":"Benson","length":206.47138,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Hardest Of Hearts","status":200,"ts":1542990577796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"She & Him","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":14,"lastName":"Rodriguez","length":134.32118,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Black Hole","status":200,"ts":1542990620796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"the bird and the bee","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":30,"lastName":"Watkins","length":229.32853,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Baby","status":200,"ts":1542990659796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Lonnie Gordon","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":15,"lastName":"Rodriguez","length":181.21098,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Catch You Baby (Steve Pitron & Max Sanna Radio Edit)","status":200,"ts":1542990754796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":14,"lastName":"Benson","length":236.09424,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Canada","status":200,"ts":1542990783796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Epidemic","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":31,"lastName":"Watkins","length":198.89587,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Walk Away (Single\/LP Version)","status":200,"ts":1542990888796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":16,"lastName":"Rodriguez","length":348.57751,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Undo","status":200,"ts":1542990935796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"TV On The Radio","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":15,"lastName":"Benson","length":336.48281,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Love Dog","status":200,"ts":1542991019796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":0,"lastName":"Williams","length":null,"level":"free","location":"Klamath Falls, OR","method":"GET","page":"Home","registration":1541077528796.0,"sessionId":878,"song":null,"status":200,"ts":1542991032796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Prince & The Revolution","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":32,"lastName":"Watkins","length":227.65669,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":691,"song":"Kiss (LP Version)","status":200,"ts":1542991086796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Paramore","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":17,"lastName":"Rodriguez","length":267.65016,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"The Only Exception (Album Version)","status":200,"ts":1542991283796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"L\u00c3\u0083\u00c2\u00a9o Ferr\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":16,"lastName":"Benson","length":144.53506,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Le Vin De L'Assassin","status":200,"ts":1542991355796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":880,"song":null,"status":200,"ts":1542991462796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"No Te Va Gustar","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":17,"lastName":"Benson","length":206.99383,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Dejame Bailar","status":200,"ts":1542991499796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Kid Cudi \/ MGMT \/ Ratatat","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":18,"lastName":"Rodriguez","length":295.67955,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Pursuit Of Happiness (nightmare)","status":200,"ts":1542991550796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Clementina De Jesus","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":18,"lastName":"Benson","length":126.58893,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Madrugada","status":200,"ts":1542991705796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Guano Apes","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":19,"lastName":"Benson","length":273.26649,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Living In A Lie","status":200,"ts":1542991831796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Dizmas","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":19,"lastName":"Rodriguez","length":228.85832,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Night Divine (On A Search In America Album Version)","status":200,"ts":1542991845796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":20,"lastName":"Rodriguez","length":264.35873,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Never Let You Go","status":200,"ts":1542992073796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Mark Ronson","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":20,"lastName":"Benson","length":238.73261,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Diduntdidunt (featuring Saigon) (Amended Version)","status":200,"ts":1542992104796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Betty Carter","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":21,"lastName":"Rodriguez","length":118.282,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Look No Further","status":200,"ts":1542992337796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Jos\u00c3\u0083\u00c2\u00a9 Gonzalez","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":21,"lastName":"Benson","length":158.48444,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Heartbeats","status":200,"ts":1542992342796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Chris Brown","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":22,"lastName":"Rodriguez","length":252.05506,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"With You","status":200,"ts":1542992455796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Elton John","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":22,"lastName":"Benson","length":417.01832,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Song For Guy","status":200,"ts":1542992500796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":23,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"Home","registration":1540907087796.0,"sessionId":852,"song":null,"status":200,"ts":1542992519796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":23,"lastName":"Rodriguez","length":290.48118,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Rabbit Heart (Raise It Up)","status":200,"ts":1542992707796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Moca","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":305.05751,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":885,"song":"Latein","status":200,"ts":1542992907796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Flogging Molly","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":24,"lastName":"Benson","length":333.53098,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"What's Left of the Flag","status":200,"ts":1542992917796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Carly Simon","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":24,"lastName":"Rodriguez","length":195.39546,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Boys In The Trees (LP Version)","status":200,"ts":1542992997796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Prodigy","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":25,"lastName":"Rodriguez","length":225.09669,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Firestarter","status":200,"ts":1542993192796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Slipknot","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":159.76444,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":885,"song":"Spit It Out [Explicit]","status":200,"ts":1542993212796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":26,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":812,"song":null,"status":200,"ts":1542993231796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Baroness","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":25,"lastName":"Benson","length":60.29016,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Blackpowder Orchard","status":200,"ts":1542993250796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Ricchi E Poveri","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":26,"lastName":"Benson","length":256.13016,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"La Prima Cosa Bella","status":200,"ts":1542993310796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":27,"lastName":"Rodriguez","length":494.99383,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Bleed It Out [Live At Milton Keynes]","status":200,"ts":1542993417796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Ed Harcourt","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":27,"lastName":"Benson","length":257.74975,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Rain On The Pretty Ones","status":200,"ts":1542993566796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"India.Arie","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":28,"lastName":"Benson","length":326.76526,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"India'Song","status":200,"ts":1542993823796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Country Joe & The Fish","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":28,"lastName":"Rodriguez","length":294.76526,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Rockin Round The World","status":200,"ts":1542993911796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"India.Arie","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":29,"lastName":"Benson","length":231.6273,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Beautiful Flower","status":200,"ts":1542994149796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Sia","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":29,"lastName":"Rodriguez","length":208.61342,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Playground","status":200,"ts":1542994205796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"FONZIE","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":30,"lastName":"Benson","length":254.56281,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Wake Up Call","status":200,"ts":1542994380796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Phil Wickham","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":30,"lastName":"Rodriguez","length":273.03138,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"The Time Is Now","status":200,"ts":1542994413796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Two Door Cinema Club","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":31,"lastName":"Benson","length":168.09751,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Undercover Martyn","status":200,"ts":1542994634796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"T.I.","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":31,"lastName":"Rodriguez","length":263.02649,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"The Greatest [Featuring Mannie Fresh] (Amended Album Version)","status":200,"ts":1542994686796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Dominique A","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":32,"lastName":"Benson","length":153.20771,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Le Courage Des Oiseaux","status":200,"ts":1542994802796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Angus & Julia Stone","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":32,"lastName":"Rodriguez","length":290.71628,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"What You Wanted","status":200,"ts":1542994949796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Eels","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":33,"lastName":"Benson","length":286.85016,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Not Ready Yet","status":200,"ts":1542994955796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"David Bowie","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":33,"lastName":"Rodriguez","length":189.98812,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Let's Spend The Night Together (1999 Digital Remaster)","status":200,"ts":1542995239796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Gov't Mule","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":34,"lastName":"Benson","length":258.14159,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":852,"song":"Mr. Man","status":200,"ts":1542995241796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Huntingtons","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":34,"lastName":"Rodriguez","length":65.85424,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"FFT (The Good_ The Bad_ And The Ugly Album Version)","status":200,"ts":1542995428796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Kathy Mattea","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":35,"lastName":"Rodriguez","length":225.59302,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Come Away With Me","status":200,"ts":1542995493796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Molotov","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":36,"lastName":"Rodriguez","length":210.07628,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Frijolero","status":200,"ts":1542995718796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Godsmack","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":37,"lastName":"Rodriguez","length":265.9522,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Moon Baby","status":200,"ts":1542995928796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":38,"lastName":"Rodriguez","length":237.26975,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":812,"song":"Trunk","status":200,"ts":1542996193796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Metallica","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":415.16363,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":869,"song":"Fade To Black","status":200,"ts":1542996661796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Raimundos","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":131.05587,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":869,"song":"Oliver'S Army","status":200,"ts":1542997076796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":2,"lastName":"Hess","length":494.99383,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":869,"song":"Bleed It Out [Live At Milton Keynes]","status":200,"ts":1542997207796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Damian Marley \/ Bunny Wailer","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":3,"lastName":"Hess","length":329.06404,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":869,"song":"Confrontation","status":200,"ts":1542997701796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":0,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":793,"song":null,"status":200,"ts":1543000666796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Mos Def","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":1,"lastName":"Young","length":188.86485,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":793,"song":"Caldonia","status":200,"ts":1543000670796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Yann Tiersen","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":120.39791,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":858,"song":"La Valse D'Am\u00c3\u0083\u00c2\u00a9lie (Version Orchestre)","status":200,"ts":1543000737796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Fatboy Slim","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":2,"lastName":"Young","length":221.51791,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":793,"song":"Everybody Needs A 303","status":200,"ts":1543000858796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Meg & Dia","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":3,"lastName":"Young","length":209.26649,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":793,"song":"Masterpiece (Album Version)","status":200,"ts":1543001079796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Chicks On Speed","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":4,"lastName":"Young","length":263.13098,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":793,"song":"Wordy Rappinghood","status":200,"ts":1543001288796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Kills","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":5,"lastName":"Young","length":231.91465,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":793,"song":"Goodnight Bad Morning","status":200,"ts":1543001551796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Jaci Velasquez","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":0,"lastName":"Young","length":200.95955,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Something (Album Version)","status":200,"ts":1543002255796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":1,"lastName":"Young","length":268.38159,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Yellow","status":200,"ts":1543002455796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Clannad","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":2,"lastName":"Young","length":299.62404,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Love And Affection","status":200,"ts":1543002723796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":3,"lastName":"Young","length":193.88036,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Gone Going","status":200,"ts":1543003022796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Evanescence","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":4,"lastName":"Young","length":273.37098,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"My Immortal (bonus)","status":200,"ts":1543003215796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Mossie","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":5,"lastName":"Young","length":147.19955,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Interlude #1 (Mama)","status":200,"ts":1543003488796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Michael W. Smith","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":6,"lastName":"Young","length":254.79791,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Draw Me Close","status":200,"ts":1543003635796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Killers","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":7,"lastName":"Young","length":258.89914,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"On Top","status":200,"ts":1543003889796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Michael Bubl\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":8,"lastName":"Young","length":184.94649,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Some Kind Of Wonderful (Non-Album Track)","status":200,"ts":1543004147796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Harmonia","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":9,"lastName":"Young","length":655.77751,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Sehr kosmisch","status":200,"ts":1543004331796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Bobby Goldsboro","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":10,"lastName":"Young","length":238.602,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Honey","status":200,"ts":1543004986796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Creedence Clearwater Revived","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":11,"lastName":"Young","length":297.87383,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Suzy Q","status":200,"ts":1543005224796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Ghostland Observatory","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":12,"lastName":"Young","length":301.13914,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Robotique Majestique (Album)","status":200,"ts":1543005521796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Feist","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":184.94649,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":889,"song":"My Moon My Man","status":200,"ts":1543005627796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Uncle Kracker","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":13,"lastName":"Young","length":216.08444,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Follow Me (Explicit LP Version)","status":200,"ts":1543005822796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Per Gessle","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":14,"lastName":"Young","length":192.67873,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Listen To Your Heart (Cologne)","status":200,"ts":1543006038796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Big & Rich","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":15,"lastName":"Young","length":298.23955,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"8th Of November (Album Version) (w\/o Intro)","status":200,"ts":1543006230796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Dead Can Dance","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":16,"lastName":"Young","length":230.05995,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"The Writing On My Father\u0019s Hand","status":200,"ts":1543006528796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":882,"song":null,"status":200,"ts":1543006613796,"userAgent":null,"userId":""} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":17,"lastName":"Young","length":195.94404,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Sincerit\u00c3\u0083\u00c2\u00a9 Et Jalousie","status":200,"ts":1543006758796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"DAVE MATTHEWS BAND","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":18,"lastName":"Young","length":109.50485,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"#40","status":200,"ts":1543006953796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":19,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Downgrade","registration":1540465241796.0,"sessionId":891,"song":null,"status":200,"ts":1543006962796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Victor Jara","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":20,"lastName":"Young","length":105.58649,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Ay Mi Palomita (1997 Digital Remaster)","status":200,"ts":1543007062796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Rose Royce","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":21,"lastName":"Young","length":275.9571,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Get Up Off Your Fat","status":200,"ts":1543007167796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Sex Pistols","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":22,"lastName":"Young","length":194.63791,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Who Was It (Demo Version Of 'EMI')","status":200,"ts":1543007442796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Devin Townsend","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":23,"lastName":"Young","length":436.40118,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"The fluke","status":200,"ts":1543007636796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Szarka Gyula","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":24,"lastName":"Young","length":243.53914,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Boriv\u00c3\u0083\u00c2\u00b3knak val\u00c3\u0083\u00c2\u00b3","status":200,"ts":1543008072796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Clash","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":25,"lastName":"Young","length":186.06975,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"I'm Not Down","status":200,"ts":1543008315796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"DJ Shadow","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":26,"lastName":"Young","length":549.56363,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Blood On The Motorway","status":200,"ts":1543008501796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Beck","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":27,"lastName":"Young","length":139.59791,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Lemonade","status":200,"ts":1543009050796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Johnny Mathis","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":28,"lastName":"Young","length":140.93016,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Misty","status":200,"ts":1543009189796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Nicolai Dunger","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":29,"lastName":"Young","length":163.65669,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":891,"song":"Our Filmscore","status":200,"ts":1543009329796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":30,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"Logout","registration":1540465241796.0,"sessionId":891,"song":null,"status":307,"ts":1543009330796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":31,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":891,"song":null,"status":200,"ts":1543009372796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Kimber","gender":"F","itemInSession":0,"lastName":"Norris","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540975589796.0,"sessionId":488,"song":null,"status":200,"ts":1543014409796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"47"} {"artist":"Miranda Cosgrove featuring Drake Bell","auth":"Logged In","firstName":"Kimber","gender":"F","itemInSession":1,"lastName":"Norris","length":161.04444,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540975589796.0,"sessionId":488,"song":"Leave It All To Me (Theme from iCarly)","status":200,"ts":1543014528796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"47"}
462.705686
586
0.697916
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"The Future Sound of London","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":405.28934,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":873,"song":"Papua New Guinea","status":200,"ts":1543020300796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Harmonia","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":655.77751,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":873,"song":"Sehr kosmisch","status":200,"ts":1543020705796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":86,"song":null,"status":200,"ts":1543026352796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":86,"song":null,"status":200,"ts":1543026402796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Help","registration":null,"sessionId":86,"song":null,"status":200,"ts":1543026454796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Help","registration":null,"sessionId":86,"song":null,"status":200,"ts":1543026488796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Help","registration":null,"sessionId":86,"song":null,"status":200,"ts":1543026518796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":5,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":86,"song":null,"status":307,"ts":1543026519796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Dustin","gender":"M","itemInSession":6,"lastName":"Lee","length":null,"level":"free","location":"Myrtle Beach-Conway-North Myrtle Beach, SC-NC","method":"GET","page":"Home","registration":1540853279796.0,"sessionId":86,"song":null,"status":200,"ts":1543026541796,"userAgent":"Mozilla\/5.0 (Windows NT 6.3; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"87"} {"artist":"My Chemical Romance","auth":"Logged In","firstName":"Dustin","gender":"M","itemInSession":7,"lastName":"Lee","length":311.11791,"level":"free","location":"Myrtle Beach-Conway-North Myrtle Beach, SC-NC","method":"PUT","page":"NextSong","registration":1540853279796.0,"sessionId":86,"song":"Welcome To The Black Parade (Album Version)","status":200,"ts":1543026602796,"userAgent":"Mozilla\/5.0 (Windows NT 6.3; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"87"} {"artist":"Disturbing Tha Peace \/ Ludacris \/ Mystikal \/ I-20","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":276.4273,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Move Bitch","status":200,"ts":1543027714796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Carlos Pai\u00c3\u0083\u00c2\u00a3o","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":185.99138,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Playback","status":200,"ts":1543027990796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"Logout","registration":1540511766796.0,"sessionId":888,"song":null,"status":307,"ts":1543027991796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":888,"song":null,"status":200,"ts":1543028006796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":888,"song":null,"status":307,"ts":1543028007796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":5,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":888,"song":null,"status":200,"ts":1543028010796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Snowgoons","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":6,"lastName":"Rodriguez","length":239.28118,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Show Love","status":200,"ts":1543028175796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Steve Miller","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":7,"lastName":"Rodriguez","length":325.22404,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Born To Be Blue","status":200,"ts":1543028414796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Creed","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":8,"lastName":"Rodriguez","length":295.3922,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"My Sacrifice","status":200,"ts":1543028739796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":9,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":888,"song":null,"status":200,"ts":1543028952796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Max Richter","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":10,"lastName":"Rodriguez","length":208.40444,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Untitled (Figures)","status":200,"ts":1543029034796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":11,"lastName":"Rodriguez","length":235.49342,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Geek In The Pink (Album Version)","status":200,"ts":1543029242796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Betty Everett","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":12,"lastName":"Rodriguez","length":139.67628,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"You're No Good","status":200,"ts":1543029477796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Madonna","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":13,"lastName":"Rodriguez","length":260.75383,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Beautiful Stranger","status":200,"ts":1543029616796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Theory Of A Deadman","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":14,"lastName":"Rodriguez","length":246.54322,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Santa Monica","status":200,"ts":1543029876796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Chris Brown","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":15,"lastName":"Rodriguez","length":203.80689,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Ain't No Way (You Won't Love Me)","status":200,"ts":1543030122796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Kansas","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":16,"lastName":"Rodriguez","length":202.29179,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Dust in The Wind","status":200,"ts":1543030325796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Lacksley Castell","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":17,"lastName":"Rodriguez","length":543.7122,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"What A Great Day","status":200,"ts":1543030527796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The White Stripes","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":18,"lastName":"Rodriguez","length":231.81016,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Seven Nation Army (Album Version)","status":200,"ts":1543031070796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Sophie B. Hawkins","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":19,"lastName":"Rodriguez","length":323.39546,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Damn I Wish I Was Your Lover","status":200,"ts":1543031301796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Nik & Jay","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":20,"lastName":"Rodriguez","length":267.49342,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"En Dag Tilbage","status":200,"ts":1543031624796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bobby McFerrin","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":21,"lastName":"Rodriguez","length":291.60444,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Don't Worry Be Happy","status":200,"ts":1543031891796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Amon Amarth","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":22,"lastName":"Rodriguez","length":407.84934,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Arson","status":200,"ts":1543032182796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Smif-n-Wessun","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":23,"lastName":"Rodriguez","length":325.72036,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"P.N.C. (LP Version)","status":200,"ts":1543032589796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":0,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":709,"song":null,"status":200,"ts":1543032771796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Static-X","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":1,"lastName":"Lynch","length":266.47465,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":709,"song":"The Trance Is The Motion [Live]","status":200,"ts":1543032774796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Mystikal","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":24,"lastName":"Rodriguez","length":254.98077,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Shake Ya Ass","status":200,"ts":1543032914796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"CKY","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":2,"lastName":"Lynch","length":208.24771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":709,"song":"All Power To Slaves","status":200,"ts":1543033040796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"This is a Process of a Still Life","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":25,"lastName":"Rodriguez","length":396.12036,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Constantly Under Surveillance","status":200,"ts":1543033168796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Vaselines","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":3,"lastName":"Lynch","length":189.98812,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":709,"song":"Sex Sux (Amen) (Album)","status":200,"ts":1543033248796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Thyrfing","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":4,"lastName":"Lynch","length":178.6771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":709,"song":"Vargavinter","status":200,"ts":1543033437796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":896,"song":null,"status":200,"ts":1543033512796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Bersuit Vergarabat","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":259.63057,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":896,"song":"La Flor De Mis Heridas","status":200,"ts":1543033538796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":26,"lastName":"Rodriguez","length":226.53342,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"After An Afternoon (Eagles Ballroom Live Version)","status":200,"ts":1543033564796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"TV On The Radio","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":5,"lastName":"Lynch","length":275.87873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":709,"song":"Province","status":200,"ts":1543033615796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Mad Flava","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":27,"lastName":"Rodriguez","length":35.81342,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Wax on Tha Belt (Baby G Gets Biz)","status":200,"ts":1543033790796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Black Sheep","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":203.15383,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":896,"song":"The Choice Is Yours","status":200,"ts":1543033797796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"The Cars","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":28,"lastName":"Rodriguez","length":234.65751,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Tonight She Comes (LP Version)","status":200,"ts":1543033825796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Presets","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":6,"lastName":"Lynch","length":271.85587,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":709,"song":"Yippiyo-Ay","status":200,"ts":1543033890796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Obk","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":3,"lastName":"Smith","length":377.15546,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":896,"song":"Lucifer (The Final Combination Mix)","status":200,"ts":1543034000796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":29,"lastName":"Rodriguez","length":275.87873,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Sun \/ C79","status":200,"ts":1543034059796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bon Iver","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":30,"lastName":"Rodriguez","length":186.122,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Creature Fear","status":200,"ts":1543034334796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Lady GaGa","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":31,"lastName":"Rodriguez","length":249.20771,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Monster","status":200,"ts":1543034520796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Vince Gill","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":32,"lastName":"Rodriguez","length":255.81669,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Feels Like Love","status":200,"ts":1543034769796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Snow Patrol","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":33,"lastName":"Rodriguez","length":195.21261,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Hands Open","status":200,"ts":1543035024796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":34,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":888,"song":null,"status":200,"ts":1543035033796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Randy Rogers Band","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":35,"lastName":"Rodriguez","length":254.58893,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"One More Goodbye","status":200,"ts":1543035219796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Joan Baez","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":36,"lastName":"Rodriguez","length":193.17506,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Don't Cry For Me Argentina","status":200,"ts":1543035473796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Natalie","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":37,"lastName":"Rodriguez","length":227.36934,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Turnin' Me On","status":200,"ts":1543035666796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":38,"lastName":"Rodriguez","length":239.3073,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"You're The One","status":200,"ts":1543035893796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Blackalicious","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":39,"lastName":"Rodriguez","length":276.92363,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Deception","status":200,"ts":1543036132796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Knux","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":40,"lastName":"Rodriguez","length":200.25424,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Bang! Bang!","status":200,"ts":1543036408796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":41,"lastName":"Rodriguez","length":315.42812,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Born On The Bayou","status":200,"ts":1543036608796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Leon Russell","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":42,"lastName":"Rodriguez","length":185.73016,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Act Naturally (Album Version)","status":200,"ts":1543036923796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Iration","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":43,"lastName":"Rodriguez","length":208.24771,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Changed My Mind","status":200,"ts":1543037108796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Natiruts","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":44,"lastName":"Rodriguez","length":210.88608,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Jamaica Roots II(Agora E Sempre)","status":200,"ts":1543037316796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The New Pornographers","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":45,"lastName":"Rodriguez","length":169.24689,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"From Blown Speakers","status":200,"ts":1543037526796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Avett Brothers","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":46,"lastName":"Rodriguez","length":287.97342,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Head Full Of Doubt\/Road Full Of Promise","status":200,"ts":1543037695796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Dina Carroll","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":47,"lastName":"Rodriguez","length":203.20608,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Someone Like You","status":200,"ts":1543037982796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Rush Of Fools","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":48,"lastName":"Rodriguez","length":219.66322,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Holy One","status":200,"ts":1543038185796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Morten Abel","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":49,"lastName":"Rodriguez","length":217.44281,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Lydia","status":200,"ts":1543038404796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Tomcraft","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":50,"lastName":"Rodriguez","length":471.45751,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Loneliness","status":200,"ts":1543038621796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":51,"lastName":"Rodriguez","length":348.57751,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Undo","status":200,"ts":1543039092796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":893,"song":null,"status":200,"ts":1543039148796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":893,"song":null,"status":307,"ts":1543039149796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":893,"song":null,"status":200,"ts":1543039183796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jos\u00c3\u0083\u00c2\u00a9 Gonzalez","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":52,"lastName":"Rodriguez","length":158.48444,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Heartbeats","status":200,"ts":1543039440796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Ween","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":276.13995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"The Stallion","status":200,"ts":1543039480796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Eminem","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":53,"lastName":"Rodriguez","length":284.86485,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"The Real Slim Shady","status":200,"ts":1543039598796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":54,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"About","registration":1540511766796.0,"sessionId":888,"song":null,"status":200,"ts":1543039715796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Robbie Dupree","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":273.68444,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"If We Try Again","status":200,"ts":1543039756796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":55,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"About","registration":1540511766796.0,"sessionId":888,"song":null,"status":200,"ts":1543039899796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Natalie MacMaster","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":56,"lastName":"Rodriguez","length":186.80118,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"The E Flat Reel\/The Recluse\/James D Law\/","status":200,"ts":1543039907796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Jeremih","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":220.55138,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"My Ride","status":200,"ts":1543040029796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Dodos","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":57,"lastName":"Rodriguez","length":374.69995,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Paint The Rust","status":200,"ts":1543040093796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Kat DeLuna","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":239.43791,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"Como Un Sue\u00c3\u0083\u00c2\u00b1o (Am I Dreaming)","status":200,"ts":1543040249796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Format","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":58,"lastName":"Rodriguez","length":199.83628,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"Tie The Rope (Album Version)","status":200,"ts":1543040467796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Molotov Solution","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":221.962,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"Awakening","status":200,"ts":1543040488796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Smash Mouth","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":59,"lastName":"Rodriguez","length":216.39791,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":888,"song":"All Star","status":200,"ts":1543040666796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"And Then There Were None","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":259.26485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"Insozzz ...","status":200,"ts":1543040709796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Lostprophets","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":244.03546,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":890,"song":"Broken Hearts_ Torn Up Letters And The Story Of A Lonely Girl","status":200,"ts":1543040876796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Philippe Rochard","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":360.51546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"Crumpshit","status":200,"ts":1543040968796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Superlitio","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":1,"lastName":"Simpson","length":247.92771,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":890,"song":"Favorite Song","status":200,"ts":1543041120796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":260.77995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"Your Star","status":200,"ts":1543041328796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":2,"lastName":"Simpson","length":252.21179,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":890,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1543041367796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Turing Machine","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":522.762,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"Robotronic","status":200,"ts":1543041588796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mighty Terror & His Calypsonians","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":137.84771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"Calypso War","status":200,"ts":1543042110796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Butterfingers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":341.75955,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"Words Vs Wisdom","status":200,"ts":1543042247796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"NB Ridaz","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":234.21342,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"Tu Eres","status":200,"ts":1543042588796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Shaggy \/ Ricardo Ducent","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Rodriguez","length":226.76853,"level":"free","location":"Los Angeles-Long Beach-Anaheim, CA","method":"PUT","page":"NextSong","registration":1540992715796.0,"sessionId":843,"song":"It Wasn't Me","status":200,"ts":1543042732796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"68"} {"artist":"Michael Bubl\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":244.21832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"You'll Never Find Another Love Like Mine (Album Version)","status":200,"ts":1543042822796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Silver Mt. Zion","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":308.53179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"Sit in the Middle of Three Galloping Dogs","status":200,"ts":1543043066796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Copeland","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":199.07873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"Chin Up","status":200,"ts":1543043374796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Red Hot Chili Peppers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":18,"lastName":"Levine","length":321.82812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"Californication (Album Version)","status":200,"ts":1543043573796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"P.O.D.","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":19,"lastName":"Levine","length":224.67873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"The Reasons (Album Version)","status":200,"ts":1543043894796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Richard Vission & Static Avanger Starring Luciana","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":20,"lastName":"Levine","length":375.43138,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"I Like That","status":200,"ts":1543044118796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"After 7","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":21,"lastName":"Levine","length":241.94567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":893,"song":"Nights Like This","status":200,"ts":1543044493796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540306145796.0,"sessionId":832,"song":null,"status":200,"ts":1543047197796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Ratatat","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":0,"lastName":"Smith","length":184.0322,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":825,"song":"Nostrand","status":200,"ts":1543048519796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Sade","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":332.12036,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":892,"song":"Cherish The Day","status":200,"ts":1543056791796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Elton John","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":417.01832,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":892,"song":"Song For Guy","status":200,"ts":1543057123796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Lewis Black","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":2,"lastName":"Hess","length":111.80363,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":892,"song":"Gamblers","status":200,"ts":1543057540796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Acoustic Alchemy","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":169.1424,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Coffee With Manni","status":200,"ts":1543058177796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Stryper","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":295.70567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Lady","status":200,"ts":1543058346796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":348.57751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Undo","status":200,"ts":1543058641796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Plain White T S","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":180.11383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Please Don't Do This (Album)","status":200,"ts":1543058989796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Blink-182","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":173.76608,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Feeling This","status":200,"ts":1543059169796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Eminem","auth":"Logged In","firstName":"Morris","gender":"M","itemInSession":0,"lastName":"Gilmore","length":248.58077,"level":"free","location":"Raleigh, NC","method":"PUT","page":"NextSong","registration":1540971561796.0,"sessionId":841,"song":"Just Lose It","status":200,"ts":1543059578796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_1 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D201 Safari\/9537.53\"","userId":"23"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":903,"song":null,"status":200,"ts":1543059681796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Original Love","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":337.76281,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Kokoro - Angel Heart (album mix)","status":200,"ts":1543059741796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"BarlowGirl","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":258.40281,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Beautiful Ending (Album)","status":200,"ts":1543060078796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Me First And The Gimme Gimmes","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":105.1424,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Phantom Of The Opera","status":200,"ts":1543060336796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"George Michael","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":302.602,"level":"free","location":"London, KY","method":"PUT","page":"NextSong","registration":1540613280796.0,"sessionId":422,"song":"Careless Whisper","status":200,"ts":1543060418796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"13"} {"artist":"Easy Star All-Stars","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":272.50893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Lucy in the Sky With Diamonds (feat. Frankie Paul)","status":200,"ts":1543060441796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Linda Ronstadt","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":181.7073,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Birds","status":200,"ts":1543060713796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":258.55955,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Cosmic Love","status":200,"ts":1543060894796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Deftones","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":241.52771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Sextape (Album Version)","status":200,"ts":1543061152796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":0,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Home","registration":1540809153796.0,"sessionId":564,"song":null,"status":200,"ts":1543061300796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Los Concorde","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":1,"lastName":"Johnson","length":223.7122,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"No Usemos Ropa Hoy","status":200,"ts":1543061374796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Early Man","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":201.32526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Fight","status":200,"ts":1543061393796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Frumpies","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":134.47791,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Fuck Kitty","status":200,"ts":1543061594796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Robben Ford","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":2,"lastName":"Johnson","length":250.53995,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Talk To Your Daughter (Album Version)","status":200,"ts":1543061597796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Loreena McKennitt","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":0,"lastName":"Santana","length":52.00934,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":807,"song":"To The Fairies They Draw Near","status":200,"ts":1543061727796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Le\u00c3\u0083\u00c2\u00b3n Gieco","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":361.27302,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Los Salieris De Charly","status":200,"ts":1543061728796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"J. Karjalainen & Mustat Lasit","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":1,"lastName":"Santana","length":336.74404,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":807,"song":"Sinisten t\u00c3\u0083\u00c2\u00a4htien alla","status":200,"ts":1543061779796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Yeah Yeah Yeahs","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":3,"lastName":"Johnson","length":125.20444,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Yeah! New York","status":200,"ts":1543061847796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"3 Doors Down","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":4,"lastName":"Johnson","length":237.13914,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Here Without You","status":200,"ts":1543061972796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Clash","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":221.6224,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Rock The Casbah","status":200,"ts":1543062089796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Freddie Bruno","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":2,"lastName":"Santana","length":230.21669,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":807,"song":"Updated & Still Hated (The Ball Point Composer Album Version)","status":200,"ts":1543062115796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Elliott Smith","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":5,"lastName":"Johnson","length":146.15465,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Everything Means Nothing To Me","status":200,"ts":1543062209796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Panic At The Disco","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":259.29098,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Behind The Sea [Live In Chicago]","status":200,"ts":1543062310796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Coldplay","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":3,"lastName":"Santana","length":294.1122,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":807,"song":"Fix You","status":200,"ts":1543062345796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Colt Ford","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":6,"lastName":"Johnson","length":222.04036,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Dirt Road Anthem (feat. Brantley Gilbert)","status":200,"ts":1543062355796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"City And Colour","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":18,"lastName":"Levine","length":208.43057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"What Makes A Man","status":200,"ts":1543062569796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Cocorosie","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":7,"lastName":"Johnson","length":280.24118,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"R.I.P. Burn Face","status":200,"ts":1543062577796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Foolish Things","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":0,"lastName":"Klein","length":266.86649,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Who Can Compare","status":200,"ts":1543062612796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Katrina & The Waves","auth":"Logged In","firstName":"Colm","gender":"M","itemInSession":4,"lastName":"Santana","length":220.9171,"level":"free","location":"Nashville-Davidson--Murfreesboro--Franklin, TN","method":"PUT","page":"NextSong","registration":1540856629796.0,"sessionId":807,"song":"Walking On Sunshine","status":200,"ts":1543062639796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"67"} {"artist":"Tricky","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":19,"lastName":"Levine","length":204.14649,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Something in the Way (Album version)","status":200,"ts":1543062777796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Moose","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":8,"lastName":"Johnson","length":215.17016,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Uptown Invisible","status":200,"ts":1543062857796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Melissa Horn","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":1,"lastName":"Klein","length":211.33016,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"S\u00c3\u0083\u00c2\u00a4g ingenting till mig","status":200,"ts":1543062878796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":2,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Home","registration":1540558108796.0,"sessionId":692,"song":null,"status":200,"ts":1543062924796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Fergie","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":20,"lastName":"Levine","length":396.12036,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Wake Up","status":200,"ts":1543062981796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Terrorvision","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":9,"lastName":"Johnson","length":160.54812,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Glad All Over","status":200,"ts":1543063072796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"David Phelps","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":3,"lastName":"Klein","length":291.47383,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"What A Meeting In The Air (Atlanta Homecoming Album Version)","status":200,"ts":1543063089796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Kills","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":10,"lastName":"Johnson","length":287.65995,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"No Wow","status":200,"ts":1543063232796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Lionel Richie","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":21,"lastName":"Levine","length":301.68771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Don't Wanna Lose You","status":200,"ts":1543063377796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Rolling Stones","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":4,"lastName":"Klein","length":271.49016,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Angie (1993 Digital Remaster)","status":200,"ts":1543063380796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Radiohead","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":11,"lastName":"Johnson","length":246.96118,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Pulk\/Pull Revolving Doors","status":200,"ts":1543063519796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Rufio","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":5,"lastName":"Klein","length":36.33587,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Raining in September","status":200,"ts":1543063651796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Bajaga & Instruktori","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":22,"lastName":"Levine","length":254.95465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Godine prolaze","status":200,"ts":1543063678796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Drowning Pool","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":6,"lastName":"Klein","length":229.35465,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Reason I'm Alive (Explicit)","status":200,"ts":1543063687796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Postal Service","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":12,"lastName":"Johnson","length":266.47465,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Such Great Heights","status":200,"ts":1543063765796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Kid Rock","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":7,"lastName":"Klein","length":296.95955,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"All Summer Long (Album Version)","status":200,"ts":1543063916796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Tears For Fears","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":23,"lastName":"Levine","length":290.89914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"Shout","status":200,"ts":1543063932796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Christopher O'Riley","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":13,"lastName":"Johnson","length":337.91955,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"paranoid android","status":200,"ts":1543064031796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Panic At The Disco","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":8,"lastName":"Klein","length":114.31138,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Folkin' Around [Live In Chicago]","status":200,"ts":1543064212796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Deadmau5 & Kaskade","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":24,"lastName":"Levine","length":595.56526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":903,"song":"I Remember","status":200,"ts":1543064222796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Eagles","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":9,"lastName":"Klein","length":234.31791,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"What Do I Do With My Heart","status":200,"ts":1543064326796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Coldplay","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":14,"lastName":"Johnson","length":311.27465,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"The Scientist","status":200,"ts":1543064368796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"J. Karjalainen & Mustat Lasit","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":10,"lastName":"Klein","length":336.74404,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Sinisten t\u00c3\u0083\u00c2\u00a4htien alla","status":200,"ts":1543064560796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Amaral","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":15,"lastName":"Johnson","length":220.81261,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Concorde","status":200,"ts":1543064679796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Flight Of The Conchords","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":11,"lastName":"Klein","length":137.482,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Boom (Album Version)","status":200,"ts":1543064896796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Buggles","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":16,"lastName":"Johnson","length":198.08608,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Video Killed The Radio Star","status":200,"ts":1543064899796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"59 Times the Pain","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":12,"lastName":"Klein","length":144.95302,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Found Home","status":200,"ts":1543065033796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Rise Against","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":17,"lastName":"Johnson","length":201.01179,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Roadside","status":200,"ts":1543065097796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":13,"lastName":"Klein","length":277.15873,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1543065177796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":18,"lastName":"Johnson","length":236.09424,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Canada","status":200,"ts":1543065298796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Wu-Tang Clan","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":14,"lastName":"Klein","length":181.60281,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Cash Still Rules\/Scary Hours (still don't nothing move but the money)","status":200,"ts":1543065454796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Killers","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":19,"lastName":"Johnson","length":265.84771,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Uncle Jonny","status":200,"ts":1543065534796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"The Strokes","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":15,"lastName":"Klein","length":219.81995,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Reptilia","status":200,"ts":1543065635796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":20,"lastName":"Johnson","length":181.26322,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Littlest Things","status":200,"ts":1543065799796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Danger Doom","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":16,"lastName":"Klein","length":160.36526,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Old School Rules (Album Version)","status":200,"ts":1543065854796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Rin\u00c3\u0083\u00c2\u00b4\u00c3\u0083\u00c2\u00a7\u00c3\u0083\u00c2\u00a9r\u00c3\u0083\u00c2\u00b4se \/ Mark Gardener","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":21,"lastName":"Johnson","length":215.09179,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Where You From?","status":200,"ts":1543065980796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Sonicflood","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":17,"lastName":"Klein","length":213.99465,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"I Could Sing Of Your Love Forever","status":200,"ts":1543066014796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":22,"lastName":"Johnson","length":231.26159,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Use Somebody","status":200,"ts":1543066195796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":23,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Settings","registration":1540809153796.0,"sessionId":564,"song":null,"status":200,"ts":1543066200796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":24,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"Logout","registration":1540809153796.0,"sessionId":564,"song":null,"status":307,"ts":1543066201796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Huey Lewis And The News","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":18,"lastName":"Klein","length":269.63546,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Stuck With You","status":200,"ts":1543066227796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":25,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":564,"song":null,"status":200,"ts":1543066393796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":26,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":564,"song":null,"status":307,"ts":1543066394796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":27,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"GET","page":"Home","registration":1540809153796.0,"sessionId":564,"song":null,"status":200,"ts":1543066411796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Edward Sharpe & The Magnetic Zeros","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":28,"lastName":"Johnson","length":306.31138,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Home","status":200,"ts":1543066426796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Stefano Prada feat. Mike Marfurt","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":19,"lastName":"Klein","length":302.13179,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Jack Explode","status":200,"ts":1543066496796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":29,"lastName":"Johnson","length":209.52771,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Float On","status":200,"ts":1543066732796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Wilco","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":20,"lastName":"Klein","length":239.98649,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Jesus_ Etc.","status":200,"ts":1543066798796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Sting","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":30,"lastName":"Johnson","length":299.96363,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"This Cowboy Song","status":200,"ts":1543066941796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Anis","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":21,"lastName":"Klein","length":246.59546,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Swing Javanaise","status":200,"ts":1543067037796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":31,"lastName":"Johnson","length":224.67873,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Secrets","status":200,"ts":1543067240796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":22,"lastName":"Klein","length":209.81506,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Intergalactic","status":200,"ts":1543067283796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Kiss the Anus of a Black Cat","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":32,"lastName":"Johnson","length":151.97995,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Prelude (\"The World is In Fear Again and It Has All Been Manufactured\")","status":200,"ts":1543067464796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Paulina Rubio","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":23,"lastName":"Klein","length":213.55057,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Nada De Ti","status":200,"ts":1543067492796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Arcade Fire","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":33,"lastName":"Johnson","length":136.69832,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Neon Bible","status":200,"ts":1543067615796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"A Fine Frenzy","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":24,"lastName":"Klein","length":245.52444,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Think Of You","status":200,"ts":1543067705796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Kid Cudi","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":34,"lastName":"Johnson","length":227.34322,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Up Up & Away","status":200,"ts":1543067751796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Katy Perry","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":25,"lastName":"Klein","length":179.40853,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"I Kissed A Girl","status":200,"ts":1543067950796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Michael Bubl\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":35,"lastName":"Johnson","length":253.88363,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Moondance (Album Version)","status":200,"ts":1543067978796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Culture Beat","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":26,"lastName":"Klein","length":257.43628,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Mr Vain","status":200,"ts":1543068129796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Vampire Weekend","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":36,"lastName":"Johnson","length":221.64853,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Walcott (Album)","status":200,"ts":1543068231796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Metro Area","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":27,"lastName":"Klein","length":339.27791,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Orange Alert (DFA Remix)","status":200,"ts":1543068386796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":37,"lastName":"Johnson","length":219.66322,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1543068452796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Karnivool","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":38,"lastName":"Johnson","length":289.30567,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Roquefort (with Empire Horns)","status":200,"ts":1543068671796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Ryan Adams","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":28,"lastName":"Klein","length":250.06975,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Sylvia Plath","status":200,"ts":1543068725796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Paramore","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":39,"lastName":"Johnson","length":215.09179,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"When It Rains (Album Version)","status":200,"ts":1543068960796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Ray J","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":29,"lastName":"Klein","length":234.26567,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Let's Play House","status":200,"ts":1543068975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Hoobastank","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":40,"lastName":"Johnson","length":199.67955,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Never Saw It Coming","status":200,"ts":1543069175796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Cosmo Vitelli","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":30,"lastName":"Klein","length":206.05342,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Robot Soul (Radio Edit)","status":200,"ts":1543069209796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Clash","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":41,"lastName":"Johnson","length":164.04853,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Hateful","status":200,"ts":1543069374796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"We Came As Romans","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":31,"lastName":"Klein","length":238.13179,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":" I Will Not Reap Destruction","status":200,"ts":1543069415796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Faith No More","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":42,"lastName":"Johnson","length":249.86077,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Last Cup Of Sorrow","status":200,"ts":1543069538796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Lesley Gore","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":32,"lastName":"Klein","length":134.37342,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"It's My Party","status":200,"ts":1543069653796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Plain White T's","auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":43,"lastName":"Johnson","length":232.202,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"NextSong","registration":1540809153796.0,"sessionId":564,"song":"Hey There Delilah","status":200,"ts":1543069787796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":"Culture Club","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":33,"lastName":"Klein","length":264.69832,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Do You Really Want To Hurt Me (2002 Digital Remaster)","status":200,"ts":1543069787796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Sara","gender":"F","itemInSession":44,"lastName":"Johnson","length":null,"level":"paid","location":"Winston-Salem, NC","method":"PUT","page":"Logout","registration":1540809153796.0,"sessionId":564,"song":null,"status":307,"ts":1543069788796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"95"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":45,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":564,"song":null,"status":200,"ts":1543069817796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":46,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"About","registration":null,"sessionId":564,"song":null,"status":200,"ts":1543069821796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":47,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"About","registration":null,"sessionId":564,"song":null,"status":200,"ts":1543069852796,"userAgent":null,"userId":""} {"artist":"Richard Clayderman","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":34,"lastName":"Klein","length":303.80363,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Rhapsody In Blue","status":200,"ts":1543070051796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"California Swag District","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":35,"lastName":"Klein","length":239.17669,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Teach Me How To Dougie","status":200,"ts":1543070354796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Red Nex","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":36,"lastName":"Klein","length":194.01098,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Cotton Eye Joe (Explicit)","status":200,"ts":1543070593796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":849,"song":null,"status":200,"ts":1543070670796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":849,"song":null,"status":307,"ts":1543070671796,"userAgent":null,"userId":""} {"artist":"Paulina Rubio","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":37,"lastName":"Klein","length":174.31465,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Un Dia Gris","status":200,"ts":1543070787796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Britney Spears","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":38,"lastName":"Klein","length":213.28934,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"3","status":200,"ts":1543070961796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Randy Crawford","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":39,"lastName":"Klein","length":270.75873,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Almaz","status":200,"ts":1543071174796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Red Elvises","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":40,"lastName":"Klein","length":207.04608,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Love Pipe","status":200,"ts":1543071444796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"U2","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":41,"lastName":"Klein","length":206.88934,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Fast Cars","status":200,"ts":1543071651796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":849,"song":null,"status":200,"ts":1543071665796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Stray Cats","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":42,"lastName":"Klein","length":355.39546,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Stray Cat Strut","status":200,"ts":1543071857796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Govi","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":43,"lastName":"Klein","length":302.47138,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Hanalei Bay","status":200,"ts":1543072212796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Frightened Rabbit","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":159.76444,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Learned Your Name","status":200,"ts":1543072504796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bruce Springsteen","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":44,"lastName":"Klein","length":311.66649,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Tunnel Of Love","status":200,"ts":1543072514796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":212.87138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Never Know","status":200,"ts":1543072663796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Molotov","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":248.65914,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":877,"song":"Marciano (I Turned Into A Martian)","status":200,"ts":1543072762796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Genesis","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":45,"lastName":"Klein","length":256.54812,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Jesus He Knows Me (2007 Digital Remaster)","status":200,"ts":1543072825796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":239.22893,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Move Along","status":200,"ts":1543072875796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"John Mayer","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":1,"lastName":"Cruz","length":201.56036,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":877,"song":"Love Song For No One","status":200,"ts":1543073010796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"Orishas","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":46,"lastName":"Klein","length":265.53424,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Mistica","status":200,"ts":1543073081796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Bobby Valentino","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":228.46649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"How 'Bout It","status":200,"ts":1543073114796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Animal Collective","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":410.90567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Fireworks","status":200,"ts":1543073342796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kaddisfly","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":47,"lastName":"Klein","length":275.27791,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"harbor","status":200,"ts":1543073346796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Revolver","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":48,"lastName":"Klein","length":318.87628,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"El mismo hombre","status":200,"ts":1543073621796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Bag Raiders","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":232.85506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Shooting Stars","status":200,"ts":1543073752796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dave Brockie Experience","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":49,"lastName":"Klein","length":116.08771,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":692,"song":"Servant Of Death's Head","status":200,"ts":1543073939796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Garbage","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":255.58159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Can't Cry These Tears","status":200,"ts":1543073984796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ry Cooder","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":223.97342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Stand By Me (LP Version)","status":200,"ts":1543074239796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":177.94567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Fake Tales Of San Francisco","status":200,"ts":1543074462796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":348.57751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Undo","status":200,"ts":1543074639796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"La Vela Puerca","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":183.19628,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"La Sin Raz\u00c3\u0083\u00c2\u00b3n","status":200,"ts":1543074987796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":910,"song":null,"status":200,"ts":1543075039796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Joshua Radin","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":202.44853,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"No Envy No Fear","status":200,"ts":1543075170796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bowling For Soup","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":188.31628,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Punk Rock 101","status":200,"ts":1543075372796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Paramore","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":267.65016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"The Only Exception (Album Version)","status":200,"ts":1543075560796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Just Jack","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":17,"lastName":"Cuevas","length":295.91465,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Starz In Their Eyes","status":200,"ts":1543075827796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":18,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Downgrade","registration":1540940782796.0,"sessionId":849,"song":null,"status":200,"ts":1543075829796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Imogen Heap","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":19,"lastName":"Cuevas","length":509.36118,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Hide & Seek","status":200,"ts":1543076122796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ray LaMontagne","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":20,"lastName":"Cuevas","length":276.87138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Shelter","status":200,"ts":1543076631796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Phil Wickham","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":21,"lastName":"Cuevas","length":293.72036,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"You're Beautiful","status":200,"ts":1543076907796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Justin Timberlake duet with Beyonce","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":22,"lastName":"Cuevas","length":322.16771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Until The End Of Time","status":200,"ts":1543077200796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Freeway","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":22.12526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"The Nation","status":200,"ts":1543077398796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Air","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":212.21832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Playground Love","status":200,"ts":1543077420796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Herv\u00c3\u0083\u00c2\u00a9 & Kissy Sellout","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":23,"lastName":"Cuevas","length":341.41995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Rikkalicious ","status":200,"ts":1543077522796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"OV7","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":222.79791,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Aum Aum","status":200,"ts":1543077632796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":0,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":898,"song":null,"status":200,"ts":1543077853796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Aerosmith","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":248.00608,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Rats In The Cellar","status":200,"ts":1543077854796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"DeBarge","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":24,"lastName":"Cuevas","length":234.03057,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Rhythm Of The Night","status":200,"ts":1543077863796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kevin Kern","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":1,"lastName":"Lynch","length":291.29098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"From This Day Forward","status":200,"ts":1543077907796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Jane Wiedlin","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":25,"lastName":"Cuevas","length":207.12444,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Blue Kiss","status":200,"ts":1543078097796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Beck","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":228.80608,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Lost Cause","status":200,"ts":1543078102796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Ana Ca\u00c3\u0083\u00c2\u00b1as","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":2,"lastName":"Lynch","length":279.50975,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"Cora\u00c3\u0083\u00c2\u00a7\u00c3\u0083\u00c2\u00a3o Vagabundo","status":200,"ts":1543078198796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Lange","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":26,"lastName":"Cuevas","length":305.84118,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Red October","status":200,"ts":1543078304796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":271.82975,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Fever","status":200,"ts":1543078330796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Train","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":3,"lastName":"Lynch","length":278.04689,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"Ramble On","status":200,"ts":1543078477796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Spiritualized","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":427.31057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Baby I'm Just A Fool","status":200,"ts":1543078601796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"System of a Down","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":27,"lastName":"Cuevas","length":228.0224,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Revenga","status":200,"ts":1543078609796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Lady GaGa","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":4,"lastName":"Lynch","length":249.20771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"Monster","status":200,"ts":1543078755796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Weird Al Yankovic","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":28,"lastName":"Cuevas","length":202.63138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Phony Calls (Parody of \"Waterfalls\" by TLC)","status":200,"ts":1543078837796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Edward Sharpe & The Magnetic Zeros","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":5,"lastName":"Lynch","length":306.31138,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"Home","status":200,"ts":1543079004796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Apocalyptica","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":275.25179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Deathzone","status":200,"ts":1543079028796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Anberlin","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":29,"lastName":"Cuevas","length":204.32934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"The Feel Good Drag","status":200,"ts":1543079039796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Skillet","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":30,"lastName":"Cuevas","length":193.25342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Whispers In The Dark (Radio Edit)","status":200,"ts":1543079243796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":220.89098,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Somebody To Love","status":200,"ts":1543079303796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Furry Lewis","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":6,"lastName":"Lynch","length":178.05016,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"Kassie Jones (Casey Jones)","status":200,"ts":1543079310796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":31,"lastName":"Cuevas","length":243.17342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Heart Cooks Brain","status":200,"ts":1543079436796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cake","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":7,"lastName":"Lynch","length":181.36771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"Conroy","status":200,"ts":1543079488796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Eddie Boyd","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":196.362,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Third Degree","status":200,"ts":1543079523796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Fergie","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":8,"lastName":"Lynch","length":263.05261,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"Voodoo Doll","status":200,"ts":1543079669796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Say Anything","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":32,"lastName":"Cuevas","length":208.77016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Walk Through Hell (featuring Max Bemis Acoustic Exclusive)","status":200,"ts":1543079679796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eastern Sun and John Kelley","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":457.50812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Rapture at Sea","status":200,"ts":1543079719796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"Logout","registration":1540794356796.0,"sessionId":910,"song":null,"status":307,"ts":1543079720796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":13,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":910,"song":null,"status":200,"ts":1543079836796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":14,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":910,"song":null,"status":307,"ts":1543079837796,"userAgent":null,"userId":""} {"artist":"Najee","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":33,"lastName":"Cuevas","length":232.4371,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"I Wish","status":200,"ts":1543079887796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Andre Hazes","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":9,"lastName":"Lynch","length":206.70649,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"Droomland (duet met Paul de Leeuw)","status":200,"ts":1543079932796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"3 Doors Down","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":34,"lastName":"Cuevas","length":233.74322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Kryptonite","status":200,"ts":1543080119796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ultra Vivid Scene","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":10,"lastName":"Lynch","length":196.93669,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"Nausea","status":200,"ts":1543080138796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Santigold","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":11,"lastName":"Lynch","length":225.35791,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"I'm A Lady [feat. Trouble Andrew]","status":200,"ts":1543080334796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":35,"lastName":"Cuevas","length":494.99383,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Bleed It Out [Live At Milton Keynes]","status":200,"ts":1543080352796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":12,"lastName":"Lynch","length":193.43628,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"From The Ritz To The Rubble","status":200,"ts":1543080559796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Owl City","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":13,"lastName":"Lynch","length":231.67955,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"Vanilla Twilight","status":200,"ts":1543080752796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Frightened Rabbit","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":36,"lastName":"Cuevas","length":327.20934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"It's Christmas So We'll Stop","status":200,"ts":1543080846796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":910,"song":null,"status":200,"ts":1543080919796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Charlie Louvin","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":14,"lastName":"Lynch","length":170.86649,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"I Think I'll Live","status":200,"ts":1543080983796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Usher Featuring Lil' Jon & Ludacris","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":250.38322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Yeah!","status":200,"ts":1543081082796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Erin McKeown","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":15,"lastName":"Lynch","length":332.85179,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"Monday Morning Cold (band)","status":200,"ts":1543081153796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"3 Doors Down","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":37,"lastName":"Cuevas","length":233.74322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Kryptonite","status":200,"ts":1543081173796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Koop","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":247.562,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Once Britten","status":200,"ts":1543081332796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Buckcherry","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":38,"lastName":"Cuevas","length":201.79546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Crazy Bitch (Album Version)","status":200,"ts":1543081406796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"3 Doors Down","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":16,"lastName":"Lynch","length":232.88118,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"Citizen\/Soldier","status":200,"ts":1543081485796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":18,"lastName":"Levine","length":220.89098,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Somebody To Love","status":200,"ts":1543081579796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Simone Cristicchi","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":39,"lastName":"Cuevas","length":144.53506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Lettera Da Volterra","status":200,"ts":1543081607796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Train","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":17,"lastName":"Lynch","length":205.45261,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":898,"song":"Marry Me","status":200,"ts":1543081717796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Yerba Buena","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":19,"lastName":"Levine","length":236.77342,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"El Burrito","status":200,"ts":1543081799796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Juanes","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":20,"lastName":"Levine","length":259.63057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Amame","status":200,"ts":1543082035796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"O'Rosko Raricim","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":21,"lastName":"Levine","length":90.56608,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Terre Promise","status":200,"ts":1543082294796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":22,"lastName":"Levine","length":268.45995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Perhaps Vampires Is A Bit Strong But...","status":200,"ts":1543082384796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"RUN-DMC","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":23,"lastName":"Levine","length":182.77832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"It's Tricky","status":200,"ts":1543082652796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Story Of The Year","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":24,"lastName":"Levine","length":191.11138,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"And The Hero Will Drown (Album Version)","status":200,"ts":1543082834796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":40,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":849,"song":null,"status":200,"ts":1543082949796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":25,"lastName":"Levine","length":200.202,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Wild World","status":200,"ts":1543083025796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":26,"lastName":"Levine","length":177.84118,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Fake Tales Of San Francisco (Explicit)","status":200,"ts":1543083225796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Antonio Vega","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":27,"lastName":"Levine","length":135.13098,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Sin Soluci\u00c3\u0083\u00c2\u00b3n","status":200,"ts":1543083402796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Symphony X","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":41,"lastName":"Cuevas","length":238.54975,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"In The Dragon's Den","status":200,"ts":1543083420796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Train","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":28,"lastName":"Levine","length":216.76363,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":910,"song":"Hey_ Soul Sister","status":200,"ts":1543083537796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Velvet Underground","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":42,"lastName":"Cuevas","length":202.762,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Train Round The Bend (LP Version)","status":200,"ts":1543083658796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The White Stripes","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":43,"lastName":"Cuevas","length":241.8673,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"My Doorbell (Album Version)","status":200,"ts":1543083860796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Little Boots","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":44,"lastName":"Cuevas","length":225.20118,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Hearts Collide (album version)","status":200,"ts":1543084101796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Flora Purim","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":45,"lastName":"Cuevas","length":306.99057,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Less Than Lovers","status":200,"ts":1543084326796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sheena Easton","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":46,"lastName":"Cuevas","length":239.62077,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Strut (1993 Digital Remaster)","status":200,"ts":1543084632796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Story Of The Year","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":47,"lastName":"Cuevas","length":232.46322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"The Dream Is Over","status":200,"ts":1543084871796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Friendly Fires","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":48,"lastName":"Cuevas","length":217.02485,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Jump In The Pool","status":200,"ts":1543085103796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Papas Da L\u00c3\u0083\u00c2\u00adngua","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":49,"lastName":"Cuevas","length":222.17098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Pequeno Grande Amor","status":200,"ts":1543085320796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Killers","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":50,"lastName":"Cuevas","length":253.70077,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Losing Touch","status":200,"ts":1543085542796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"KMC Featuring Beenie Man","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":264.80281,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":906,"song":"Soul On Fire (Drum Majorz Club Remix) (Feat. Beenie Man)","status":200,"ts":1543085791796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Dangerdoom","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":51,"lastName":"Cuevas","length":146.85995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Crosshairs","status":200,"ts":1543085795796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Avett Brothers","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":52,"lastName":"Cuevas","length":244.61016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"A Gift For Melody Anne","status":200,"ts":1543085941796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dave Attell","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":66.55955,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":906,"song":"Fireworks (LP Version)","status":200,"ts":1543086055796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Robert Johnson","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":2,"lastName":"Hess","length":154.09587,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":906,"song":"I?'m A Steady Rollin? Man","status":200,"ts":1543086121796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Homesick James","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":53,"lastName":"Cuevas","length":199.65342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"Working With Homesick","status":200,"ts":1543086185796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Mc Chris","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":3,"lastName":"Hess","length":149.99465,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":906,"song":"Nrrrd Grrrl","status":200,"ts":1543086275796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Jack's Mannequin","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":54,"lastName":"Cuevas","length":223.21587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":849,"song":"American Love (Album Version)","status":200,"ts":1543086384796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Aqua","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":4,"lastName":"Hess","length":218.48771,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":906,"song":"Cartoon Heroes","status":200,"ts":1543086424796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Metric","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":5,"lastName":"Hess","length":252.99546,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":906,"song":"Stadium Love","status":200,"ts":1543086642796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Enrique Iglesias","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":0,"lastName":"White","length":208.5873,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":867,"song":"Escape","status":200,"ts":1543092145796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Motion City Soundtrack","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":1,"lastName":"White","length":205.26975,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":867,"song":"Fell In Love Without You (Acoustic)","status":200,"ts":1543092353796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Ticanaf","auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":2,"lastName":"White","length":2594.87302,"level":"free","location":"Lubbock, TX","method":"PUT","page":"NextSong","registration":1540708070796.0,"sessionId":867,"song":"The Thousand Names of Lord Shiva (Part 1)","status":200,"ts":1543092558796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"The Far East Movement","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":228.20526,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":899,"song":"Dance Like Michael Jackson","status":200,"ts":1543097750796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"the bird and the bee","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":189.51791,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":899,"song":"You're A Cad","status":200,"ts":1543097978796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Shakira","auth":"Logged In","firstName":"Christian","gender":"F","itemInSession":0,"lastName":"Porter","length":193.82812,"level":"free","location":"Elkhart-Goshen, IN","method":"PUT","page":"NextSong","registration":1540897318796.0,"sessionId":366,"song":"Inevitable","status":200,"ts":1543103174796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"11"}
474.47486
601
0.699599
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"matchbox twenty","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":0,"lastName":"Duffy","length":177.65832,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":846,"song":"Argue (LP Version)","status":200,"ts":1543109954796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"The Lonely Island \/ T-Pain","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":1,"lastName":"Duffy","length":156.23791,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":846,"song":"I'm On A Boat","status":200,"ts":1543110131796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":2,"lastName":"Duffy","length":null,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"GET","page":"Home","registration":1540146037796.0,"sessionId":846,"song":null,"status":200,"ts":1543110132796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":3,"lastName":"Duffy","length":null,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"GET","page":"Settings","registration":1540146037796.0,"sessionId":846,"song":null,"status":200,"ts":1543110168796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":4,"lastName":"Duffy","length":null,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"Save Settings","registration":1540146037796.0,"sessionId":846,"song":null,"status":307,"ts":1543110169796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"John Mayer","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":0,"lastName":"Scott","length":275.27791,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":856,"song":"All We Ever Do Is Say Goodbye","status":200,"ts":1543113347796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":null,"auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":1,"lastName":"Scott","length":null,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"GET","page":"Home","registration":1540872073796.0,"sessionId":856,"song":null,"status":200,"ts":1543113365796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"10_000 Maniacs","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":2,"lastName":"Scott","length":251.8722,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":856,"song":"Gun Shy (LP Version)","status":200,"ts":1543113622796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Leona Lewis","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":203.88526,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"Forgive Me","status":200,"ts":1543122348796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Nine Inch Nails","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":277.83791,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"La Mer","status":200,"ts":1543122551796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Audioslave","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":334.91546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"I Am The Highway","status":200,"ts":1543122828796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kid Rock","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":296.95955,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"All Summer Long (Album Version)","status":200,"ts":1543123162796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Jets","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":220.89098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"I Do You","status":200,"ts":1543123458796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Gerbils","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":27.01016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"(iii)","status":200,"ts":1543123678796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Damian Marley \/ Stephen Marley \/ Yami Bolo","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":304.69179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"Still Searching","status":200,"ts":1543123705796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":916,"song":null,"status":200,"ts":1543124166796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Bloody Beetroots","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":201.97832,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"Warp 1.9 (feat. Steve Aoki)","status":200,"ts":1543124951796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":916,"song":null,"status":200,"ts":1543125120796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Specials","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":188.81261,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"Rat Race","status":200,"ts":1543125152796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Lively Ones","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":142.52363,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"Walkin' The Board (LP Version)","status":200,"ts":1543125340796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Katie Melua","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":252.78649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"Blues In The Night","status":200,"ts":1543125482796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":243.48689,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"I'm Yours (Album Version)","status":200,"ts":1543125734796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Fisher","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":133.98159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"Rianna","status":200,"ts":1543125977796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Zee Avi","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":160.62649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"No Christmas For Me","status":200,"ts":1543126110796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":289.12281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"I Gotta Feeling","status":200,"ts":1543126270796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Emiliana Torrini","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":17,"lastName":"Cuevas","length":184.29342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"Sunny Road","status":200,"ts":1543126559796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":18,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":916,"song":null,"status":200,"ts":1543126820796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Days Of The New","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":19,"lastName":"Cuevas","length":258.5073,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"The Down Town","status":200,"ts":1543128418796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Julio Iglesias duet with Willie Nelson","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":20,"lastName":"Cuevas","length":212.16608,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":916,"song":"To All The Girls I've Loved Before (With Julio Iglesias)","status":200,"ts":1543128676796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":0,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":914,"song":null,"status":200,"ts":1543133256796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Jason Mraz & Colbie Caillat","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Roth","length":189.6224,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":704,"song":"Lucky (Album Version)","status":200,"ts":1543135208796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":null,"auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Home","registration":1541044398796.0,"sessionId":901,"song":null,"status":200,"ts":1543145299796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"R. Kelly","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":1,"lastName":"Simpson","length":234.39628,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":901,"song":"The World's Greatest","status":200,"ts":1543145305796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":null,"auth":"Logged In","firstName":"Kynnedi","gender":"F","itemInSession":0,"lastName":"Sanchez","length":null,"level":"free","location":"Cedar Rapids, IA","method":"GET","page":"Home","registration":1541079034796.0,"sessionId":804,"song":null,"status":200,"ts":1543151224796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_8_5) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"89"} {"artist":"Jacky Terrasson","auth":"Logged In","firstName":"Marina","gender":"F","itemInSession":0,"lastName":"Sutton","length":342.7522,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1541064343796.0,"sessionId":373,"song":"Le Jardin d'Hiver","status":200,"ts":1543154200796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"48"} {"artist":"Papa Roach","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Harris","length":202.1873,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":813,"song":"Alive","status":200,"ts":1543155228796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Burt Bacharach","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Harris","length":156.96934,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":813,"song":"Casino Royale Theme (Main Title)","status":200,"ts":1543155430796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":923,"song":null,"status":200,"ts":1543161483796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Floetry","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":254.48444,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":923,"song":"Sunshine","status":200,"ts":1543161985796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Rakes","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":225.2273,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":923,"song":"Leave The City And Come Home","status":200,"ts":1543162239796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":239.3073,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":923,"song":"You're The One","status":200,"ts":1543162464796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ween","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":228.10077,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":923,"song":"Voodoo Lady","status":200,"ts":1543162703796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Caf\u00c3\u0083\u00c2\u00a9 Quijano","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":197.32853,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":923,"song":"La Lola","status":200,"ts":1543162931796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Roth","length":null,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"GET","page":"Home","registration":1540699429796.0,"sessionId":925,"song":null,"status":200,"ts":1543166945796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":"Parov Stelar","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Roth","length":203.65016,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":925,"song":"Good Bye Emily (feat. Gabriella Hanninen)","status":200,"ts":1543166945796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Roth","length":null,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"GET","page":"Home","registration":1540699429796.0,"sessionId":925,"song":null,"status":200,"ts":1543166953796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":915,"song":null,"status":200,"ts":1543169974796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bryan Adams","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":166.29506,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":915,"song":"I Will Always Return","status":200,"ts":1543170092796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"KT Tunstall","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":192.31302,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":915,"song":"White Bird","status":200,"ts":1543170258796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Technicolour","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":235.12771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":915,"song":"Turn Away","status":200,"ts":1543170450796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Dears","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":289.95873,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":915,"song":"Lost In The Plot","status":200,"ts":1543170685796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Go West","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":259.49995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":915,"song":"Never Let Them See You Sweat","status":200,"ts":1543170974796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"Logout","registration":1540794356796.0,"sessionId":915,"song":null,"status":307,"ts":1543170975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Home","registration":1540266185796.0,"sessionId":912,"song":null,"status":200,"ts":1543170999796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":7,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":915,"song":null,"status":200,"ts":1543171228796,"userAgent":null,"userId":""} {"artist":"Gondwana","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":262.5824,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":814,"song":"Mi Princesa","status":200,"ts":1543189690796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":null,"auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":null,"level":"free","location":"Harrisburg-Carlisle, PA","method":"GET","page":"Home","registration":1540006905796.0,"sessionId":855,"song":null,"status":200,"ts":1543189812796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":"Ella Fitzgerald","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":1,"lastName":"Hicks","length":427.15383,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":814,"song":"On Green Dolphin Street (Medley) (1999 Digital Remaster)","status":200,"ts":1543189952796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":2,"lastName":"Hicks","length":184.73751,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":814,"song":"Run Through The Jungle","status":200,"ts":1543190379796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"}
443.322034
515
0.697681
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Muse","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":3,"lastName":"Hicks","length":259.26485,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":814,"song":"Supermassive Black Hole [Phones Control Voltage Remix]","status":200,"ts":1543190563796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":null,"auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":4,"lastName":"Hicks","length":null,"level":"free","location":"Salinas, CA","method":"PUT","page":"Logout","registration":1540008898796.0,"sessionId":814,"song":null,"status":307,"ts":1543190564796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":5,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":814,"song":null,"status":200,"ts":1543190570796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":6,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":814,"song":null,"status":307,"ts":1543190571796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":7,"lastName":"Hicks","length":null,"level":"free","location":"Salinas, CA","method":"GET","page":"Home","registration":1540008898796.0,"sessionId":814,"song":null,"status":200,"ts":1543190601796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":842,"song":null,"status":200,"ts":1543193238796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Mobin Master Feat. Robin S.","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":428.64281,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":842,"song":"Show Me Love","status":200,"ts":1543193241796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Duncan Dhu","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":0,"lastName":"Harris","length":211.90485,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":827,"song":"Rozando La Eternidad","status":200,"ts":1543193525796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"New Found Glory","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":1,"lastName":"Harris","length":222.69342,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":827,"song":"the king of wishful thinking","status":200,"ts":1543193736796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Reel Big Fish","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":2,"lastName":"Harris","length":210.65098,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":827,"song":"Beer","status":200,"ts":1543193958796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"3 Doors Down","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":0,"lastName":"Smith","length":227.7873,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":905,"song":"Pages","status":200,"ts":1543202739796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Hird","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":1,"lastName":"Smith","length":396.64281,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":905,"song":"Keep You Kimi (Feat. Yukimi Nagano)","status":200,"ts":1543202966796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Vampire Weekend","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":2,"lastName":"Smith","length":255.81669,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":905,"song":"M79 (Album)","status":200,"ts":1543203362796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":null,"auth":"Logged In","firstName":"Preston","gender":"M","itemInSession":0,"lastName":"Sanders","length":null,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"GET","page":"Home","registration":1540585584796.0,"sessionId":115,"song":null,"status":200,"ts":1543206321796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"21"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":930,"song":null,"status":200,"ts":1543210638796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":null,"level":"free","location":"New Haven-Milford, CT","method":"GET","page":"Home","registration":1540931983796.0,"sessionId":859,"song":null,"status":200,"ts":1543212983796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Scars On Broadway","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":187.34975,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"Insane","status":200,"ts":1543214124796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Death From Above 1979","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":153.88689,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"Cold War","status":200,"ts":1543214311796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":0,"lastName":"Harris","length":null,"level":"free","location":"Eugene, OR","method":"GET","page":"Home","registration":1540906915796.0,"sessionId":937,"song":null,"status":200,"ts":1543214445796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Nessbeal","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":249.52118,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"Emmur\u00c3\u0083\u00c2\u00a9 Vivant","status":200,"ts":1543214464796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"311","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":204.14649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"Jackolantern's Weather","status":200,"ts":1543214713796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Octopus Project","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":1,"lastName":"Harris","length":350.40608,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":937,"song":"Crying At The Aquarium","status":200,"ts":1543214745796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Tech N9ne","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":232.82893,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"Flash","status":200,"ts":1543214917796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Classified","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":2,"lastName":"Harris","length":272.90077,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":937,"song":"All About U","status":200,"ts":1543215095796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Ratt","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":205.97506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"Lay It Down (2007 Remastered)","status":200,"ts":1543215149796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Mya \/ Jadakiss","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":253.28281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"Best Of Me","status":200,"ts":1543215354796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Catupecu Machu","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":3,"lastName":"Harris","length":191.79057,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":937,"song":"Y Lo Que Quiero Es Que Pises Sin El Suelo","status":200,"ts":1543215367796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"R.E.M.","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":252.73424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"Burning Down","status":200,"ts":1543215607796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":0,"lastName":"Barrera","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540835983796.0,"sessionId":778,"song":null,"status":200,"ts":1543215701796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Rufus Wainwright","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":249.62567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"Hallelujah","status":200,"ts":1543215859796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Waterboys","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":382.37995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"Bury My Heart","status":200,"ts":1543216108796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Diana Ross","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":130.97751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"Don't Explain","status":200,"ts":1543216490796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Lonely Island \/ Jack Black","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":126.74567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"Sax Man","status":200,"ts":1543216620796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Deadmau5 & Kaskade","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":335.15057,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"I Remember (Caspa Remix)","status":200,"ts":1543216746796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Chiodos","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":226.16771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":930,"song":"Life Is A Perception Of Your Own Reality (Album Version)","status":200,"ts":1543217081796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Stray Cats","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":195.05587,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Ubangi Stomp","status":200,"ts":1543217917796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Settings","registration":1541022995796.0,"sessionId":781,"song":null,"status":200,"ts":1543217943796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Phantom Planet","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":199.6273,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"California","status":200,"ts":1543218112796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":3,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":781,"song":null,"status":200,"ts":1543218125796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Alejandro Sanz","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":4,"lastName":"Kirby","length":230.24281,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Non E_ Per Te_ Per Me","status":200,"ts":1543218311796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Settings","registration":1540940782796.0,"sessionId":930,"song":null,"status":200,"ts":1543218414796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"Logout","registration":1540940782796.0,"sessionId":930,"song":null,"status":307,"ts":1543218415796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Macaco","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":5,"lastName":"Kirby","length":204.90404,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Somos Luz","status":200,"ts":1543218541796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Marcy Playground","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":6,"lastName":"Kirby","length":150.83057,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Pigeon Farm","status":200,"ts":1543218745796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Catupecu Machu","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":7,"lastName":"Kirby","length":251.45424,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Plan B: Anhelo De Satisfacci\u00c3\u0083\u00c2\u00b3n","status":200,"ts":1543218895796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Vector Lovers","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":8,"lastName":"Kirby","length":260.70159,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Neon Sky Rain","status":200,"ts":1543219146796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Blondie","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":9,"lastName":"Kirby","length":273.05751,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Atomic '98 (Xenomania Mix)","status":200,"ts":1543219406796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Red Hot Chili Peppers","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":10,"lastName":"Kirby","length":365.53098,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Turn It Again (Album Version)","status":200,"ts":1543219679796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":17,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":930,"song":null,"status":200,"ts":1543219841796,"userAgent":null,"userId":""} {"artist":"KT Tunstall","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":11,"lastName":"Kirby","length":197.56363,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Throw Me A Rope","status":200,"ts":1543220044796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":12,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":781,"song":null,"status":200,"ts":1543220046796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Depreciation Guild","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":13,"lastName":"Kirby","length":308.08771,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Dream About Me","status":200,"ts":1543220241796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Devendra Banhart","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":14,"lastName":"Kirby","length":286.30159,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"I Feel Just Like a Child","status":200,"ts":1543220549796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Eddie Santiago","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":263.20934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":837,"song":"Hasta Aqui Te Fui Fiel","status":200,"ts":1543220665796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bloc Party","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":15,"lastName":"Kirby","length":222.04036,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Plans (Replanned by Mogwai)","status":200,"ts":1543220835796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Sanctus Real","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":209.89342,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":837,"song":"Possibilities (The Face Of Love Album Version)","status":200,"ts":1543220928796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Soltero","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":16,"lastName":"Kirby","length":182.12526,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Songs Of The Season","status":200,"ts":1543221057796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Graham Coxon","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":260.20526,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":837,"song":"Sorrow's Army","status":200,"ts":1543221137796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"De-Phazz","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":17,"lastName":"Kirby","length":205.42649,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Astrud Astronette","status":200,"ts":1543221239796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"PAULA COLE","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":266.65751,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":837,"song":"Where Have All The Cowboys Gone? (Album Version)","status":200,"ts":1543221397796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Blind Pilot","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":18,"lastName":"Kirby","length":265.7171,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"3 Rounds and a Sound","status":200,"ts":1543221444796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":219.66322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":837,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1543221663796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"El Cuarteto De Nos","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":19,"lastName":"Kirby","length":255.97342,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Yendo A La Casa De Dami\u00c3\u0083\u00c2\u00a1n","status":200,"ts":1543221709796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Clarika","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":201.84771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":837,"song":"Les Gar\u00c3\u0083\u00c2\u00a7ons Dans Les Vestiaires","status":200,"ts":1543221882796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Mos Def","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":20,"lastName":"Kirby","length":142.99383,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"The Boogie Man Song","status":200,"ts":1543221964796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":201.79546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":837,"song":"Revelry","status":200,"ts":1543222083796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Love Is All","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":21,"lastName":"Kirby","length":374.72608,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Turn The Radio Off (Maps Remix)","status":200,"ts":1543222106796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Two Door Cinema Club","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":207.43791,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":837,"song":"Costume Party","status":200,"ts":1543222284796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Downgrade","registration":1540472624796.0,"sessionId":837,"song":null,"status":200,"ts":1543222376796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Bring Me The Horizon","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":22,"lastName":"Kirby","length":115.77424,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Football Season Is Over (Album Version)","status":200,"ts":1543222480796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"T.I.","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":23,"lastName":"Kirby","length":185.10322,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":781,"song":"Look What I Got (Edited Album Version)","status":200,"ts":1543222595796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":24,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"Logout","registration":1541022995796.0,"sessionId":781,"song":null,"status":307,"ts":1543222596796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":25,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":781,"song":null,"status":200,"ts":1543222646796,"userAgent":null,"userId":""} {"artist":"Des'ree","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":196.51873,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":919,"song":"Life","status":200,"ts":1543226196796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"The Beach Boys","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":0,"lastName":"Williams","length":140.19873,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":883,"song":"Let's Go Away For Awhile (Highlights From Tracking Date)","status":200,"ts":1543226410796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":"Steppenwolf","auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":1,"lastName":"Williams","length":270.28853,"level":"free","location":"Klamath Falls, OR","method":"PUT","page":"NextSong","registration":1541077528796.0,"sessionId":883,"song":"Magic Carpet Ride","status":200,"ts":1543226550796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":null,"auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":null,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1541032432796.0,"sessionId":870,"song":null,"status":200,"ts":1543227097796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"The Carter Family","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":1,"lastName":"Owens","length":171.54567,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":870,"song":"Little Log Cabin By The Sea","status":200,"ts":1543227660796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":834,"song":null,"status":307,"ts":1543228677796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"GET","page":"Home","registration":1541048010796.0,"sessionId":834,"song":null,"status":200,"ts":1543228683796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Expos\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Koch","length":230.922,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"I'll Never Get Over You Getting Over Me","status":200,"ts":1543228693796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bettye Lavette","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":3,"lastName":"Koch","length":225.82812,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"I Still Want To Be Your Baby (Take Me Like I Am)","status":200,"ts":1543228923796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Phil Collins","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":241.03138,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":851,"song":"Look Through My Eyes","status":200,"ts":1543229098796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":4,"lastName":"Koch","length":406.17751,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Paradise City","status":200,"ts":1543229148796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Floyd Cramer","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":1,"lastName":"Johnson","length":202.68363,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":851,"song":"Have I Told You Lately","status":200,"ts":1543229339796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"Queen","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":5,"lastName":"Koch","length":212.16608,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Death On Two Legs (Dedicated To....) (Live) (1994 Digital Remaster)","status":200,"ts":1543229554796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"M83","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":6,"lastName":"Koch","length":175.46404,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Teen Angst","status":200,"ts":1543229766796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":7,"lastName":"Koch","length":348.57751,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Undo","status":200,"ts":1543229941796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"L.O.X.","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":8,"lastName":"Koch","length":253.25669,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Recognize","status":200,"ts":1543230289796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":9,"lastName":"Koch","length":216.39791,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Fans","status":200,"ts":1543230542796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Sugar Ray","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":10,"lastName":"Koch","length":243.33016,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Someday (Remastered LP Version)","status":200,"ts":1543230758796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"N.E.R.D.","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":11,"lastName":"Koch","length":259.23873,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Rock Star","status":200,"ts":1543231001796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Medeski_ Martin & Wood","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":12,"lastName":"Koch","length":218.40934,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Uninvisible","status":200,"ts":1543231260796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Chad & Jeremy","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":13,"lastName":"Koch","length":153.83465,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"A Summer Song","status":200,"ts":1543231478796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Sonics","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":14,"lastName":"Koch","length":183.09179,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Have Love_ Will Travel","status":200,"ts":1543231631796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Hot Chip","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":15,"lastName":"Koch","length":337.99791,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"No Fit State","status":200,"ts":1543231814796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Evanescence","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":16,"lastName":"Koch","length":255.13751,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Missing (Live in Europe)","status":200,"ts":1543232151796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Hardrive","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":17,"lastName":"Koch","length":191.242,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Deep Inside (Harry Choo Choo Romero's Bambossa Remix)","status":200,"ts":1543232406796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"The Cinematic Orchestra","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":18,"lastName":"Koch","length":613.74649,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Burn Out","status":200,"ts":1543232597796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Coldplay","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":19,"lastName":"Koch","length":318.6673,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Politik","status":200,"ts":1543233210796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":20,"lastName":"Koch","length":319.42485,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Human After All","status":200,"ts":1543233528796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Rise Against","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":21,"lastName":"Koch","length":242.25914,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Savior","status":200,"ts":1543233847796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Captain & Tennille","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":22,"lastName":"Koch","length":199.36608,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Love Will Keep Us Together","status":200,"ts":1543234089796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":"Mondo Marcio","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":23,"lastName":"Koch","length":263.60118,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541048010796.0,"sessionId":834,"song":"Purple Weed","status":200,"ts":1543234288796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":24,"lastName":"Koch","length":null,"level":"paid","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"Logout","registration":1541048010796.0,"sessionId":834,"song":null,"status":307,"ts":1543234289796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"15"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":25,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":834,"song":null,"status":200,"ts":1543234293796,"userAgent":null,"userId":""} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":255.50322,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"The Remedy (I Won't Worry) (New EQ'd LP Version)","status":200,"ts":1543234404796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Those Dancing Days","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":0,"lastName":"Cook","length":197.90322,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":822,"song":"Run Run","status":200,"ts":1543234476796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Wiz Khalifa","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":155.402,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Ink My Whole Body","status":200,"ts":1543234659796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Maya Nasri","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":1,"lastName":"Cook","length":245.75955,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":822,"song":"Wayli Aah","status":200,"ts":1543234673796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Mat Kearney","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":217.5473,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Closer To Love","status":200,"ts":1543234814796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Jukebox The Ghost","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":3,"lastName":"Rodriguez","length":224.36526,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Victoria","status":200,"ts":1543235031796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Lower Class Brats","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":4,"lastName":"Rodriguez","length":142.23628,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Sex And Violence","status":200,"ts":1543235255796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bon Jovi","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":5,"lastName":"Rodriguez","length":250.69669,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Livin' On A Prayer","status":200,"ts":1543235397796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Faith No More","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":6,"lastName":"Rodriguez","length":291.42159,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Epic","status":200,"ts":1543235647796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":945,"song":null,"status":200,"ts":1543235691796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Help","registration":null,"sessionId":945,"song":null,"status":200,"ts":1543235713796,"userAgent":null,"userId":""} {"artist":"Metallica","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":7,"lastName":"Rodriguez","length":389.98159,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Eye Of The Beholder","status":200,"ts":1543235938796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Belphegor","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":276.63628,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":904,"song":"Reichswehr In Blood","status":200,"ts":1543236038796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Bond","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Smith","length":208.16934,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":904,"song":"Victory","status":200,"ts":1543236314796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Usher featuring will.i.am","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":8,"lastName":"Rodriguez","length":395.72853,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"OMG","status":200,"ts":1543236327796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":9,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Help","registration":1540511766796.0,"sessionId":900,"song":null,"status":200,"ts":1543236573796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":10,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Downgrade","registration":1540511766796.0,"sessionId":900,"song":null,"status":200,"ts":1543236744796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":11,"lastName":"Rodriguez","length":256.31302,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Why Worry","status":200,"ts":1543236877796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Vangelis","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":0,"lastName":"Klein","length":327.52281,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":913,"song":"Wait For Me","status":200,"ts":1543236931796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"David Archuleta","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":12,"lastName":"Rodriguez","length":205.26975,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"To Be With You","status":200,"ts":1543237133796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":1,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"About","registration":1540558108796.0,"sessionId":913,"song":null,"status":200,"ts":1543237139796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Hercules And Love Affair","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":13,"lastName":"Rodriguez","length":471.74485,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Blind (Frankie Knuckles Remix)","status":200,"ts":1543237338796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"3 Doors Down","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":14,"lastName":"Rodriguez","length":237.13914,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Here Without You","status":200,"ts":1543237809796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Natalie Imbruglia","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":15,"lastName":"Rodriguez","length":216.39791,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Stuck On The Moon","status":200,"ts":1543238046796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Josh Turner","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":16,"lastName":"Rodriguez","length":207.93424,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"What It Ain't","status":200,"ts":1543238262796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Ryan Adams & The Cardinals","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":17,"lastName":"Rodriguez","length":275.22567,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Dear John","status":200,"ts":1543238469796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Nicky Jam","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":18,"lastName":"Rodriguez","length":178.33751,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Me Voy Pal Party","status":200,"ts":1543238744796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":0,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":808,"song":null,"status":200,"ts":1543238833796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Flo Rida","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":1,"lastName":"Jones","length":264.88118,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":808,"song":"Available [feat. Akon] (Album Version)","status":200,"ts":1543238853796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"M83","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":19,"lastName":"Rodriguez","length":637.3873,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Lower Your Eyelids To Die With The Sun","status":200,"ts":1543238922796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":936,"song":null,"status":200,"ts":1543239045796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Quantic","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":240.22159,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":936,"song":"Sound Of Everything Feat. Alice Russell","status":200,"ts":1543239055796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":936,"song":null,"status":200,"ts":1543239086796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Horse Feathers","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":2,"lastName":"Jones","length":175.15057,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":808,"song":"Dustbowl","status":200,"ts":1543239117796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Kelly Clarkson","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":3,"lastName":"Jones","length":281.5473,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":808,"song":"Already Gone","status":200,"ts":1543239292796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Dimmu Borgir","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":20,"lastName":"Rodriguez","length":216.65914,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Perfection Or Vanity-Outro","status":200,"ts":1543239559796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Jeremih","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":4,"lastName":"Jones","length":227.26485,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":808,"song":"Birthday Sex","status":200,"ts":1543239573796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Paramore","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":21,"lastName":"Rodriguez","length":243.51302,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Emergency (Album Version)","status":200,"ts":1543239775796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Animal Collective","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":5,"lastName":"Jones","length":410.90567,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":808,"song":"Fireworks","status":200,"ts":1543239800796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Depeche Mode","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":22,"lastName":"Rodriguez","length":174.39302,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Jazz Thieves","status":200,"ts":1543240018796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Tego Calderon","auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":0,"lastName":"Garrison","length":151.74485,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"PUT","page":"NextSong","registration":1540832693796.0,"sessionId":874,"song":"Pa' Que Retozen (Amended Version)","status":200,"ts":1543240055796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":"Skillet","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":23,"lastName":"Rodriguez","length":210.78159,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"The Last Night (Album Version)","status":200,"ts":1543240192796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Vandals","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":6,"lastName":"Jones","length":271.67302,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":808,"song":"My Girlfriend's Dead","status":200,"ts":1543240210796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Stars","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":24,"lastName":"Rodriguez","length":406.85669,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"In Our Bedroom After The War","status":200,"ts":1543240402796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Charlotte Sometimes","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":7,"lastName":"Jones","length":173.68771,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":808,"song":"How I Could Just Kill A Man","status":200,"ts":1543240481796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":0,"lastName":"Brock","length":null,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"GET","page":"Home","registration":1540852600796.0,"sessionId":381,"song":null,"status":200,"ts":1543240515796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Usher","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":1,"lastName":"Brock","length":224.10404,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Hey Daddy (Daddy's Home)","status":200,"ts":1543240517796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Groove Armada","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":2,"lastName":"Brock","length":357.61587,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Edge Hill","status":200,"ts":1543240741796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Keith Sweat Featuring Athena Cage","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":25,"lastName":"Rodriguez","length":263.96689,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Nobody (Featuring Athena Cage) (LP Version)","status":200,"ts":1543240808796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Frightened Rabbit","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":26,"lastName":"Rodriguez","length":259.02975,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Swim Until You Can\u0019t See Land","status":200,"ts":1543241071796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Gilgamesh","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":3,"lastName":"Brock","length":44.30322,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Just C","status":200,"ts":1543241098796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Owl City","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":4,"lastName":"Brock","length":231.67955,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Vanilla Twilight","status":200,"ts":1543241142796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Frumpies","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":27,"lastName":"Rodriguez","length":134.47791,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Fuck Kitty","status":200,"ts":1543241330796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"T\u00c3\u0083\u00c2\u00a9l\u00c3\u0083\u00c2\u00a9phone","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":5,"lastName":"Brock","length":363.67628,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Flipper","status":200,"ts":1543241373796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":28,"lastName":"Rodriguez","length":200.61995,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Cold Day In The Sun","status":200,"ts":1543241464796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":29,"lastName":"Rodriguez","length":348.57751,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Undo","status":200,"ts":1543241664796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"DecembeRadio","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":249.62567,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":886,"song":"Find You Waiting","status":200,"ts":1543241727796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Grizzly Bear","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":6,"lastName":"Brock","length":199.78404,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Reprise","status":200,"ts":1543241736796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Incubus","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":7,"lastName":"Brock","length":257.25342,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Dig","status":200,"ts":1543241935796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"The Maine","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":182.83057,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":886,"song":"I Wanna Love You (Akon Cover) ( Compilation)","status":200,"ts":1543241976796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Phoenix","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":30,"lastName":"Rodriguez","length":179.85261,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Everything Is Everything","status":200,"ts":1543242012796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Ill Ni\u00c3\u0083\u00c2\u00b1o","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Burns","length":172.9824,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":886,"song":"Re-Birth","status":200,"ts":1543242158796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Rachael Yamagata","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":31,"lastName":"Rodriguez","length":242.75546,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"1963","status":200,"ts":1543242191796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Rammstein","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":8,"lastName":"Brock","length":284.89098,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"FR\u00c3\u0083\u00c2\u00bcHLING IN PARIS","status":200,"ts":1543242192796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Moderat","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":32,"lastName":"Rodriguez","length":341.55057,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Out Of Sight","status":200,"ts":1543242433796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Gabe Dixon Band","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":9,"lastName":"Brock","length":174.62812,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Till You're Gone","status":200,"ts":1543242476796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"The Pussycat Dolls","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":10,"lastName":"Brock","length":207.56853,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Stickwitu","status":200,"ts":1543242650796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Akala","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":33,"lastName":"Rodriguez","length":238.44526,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Comedy Tragedy History","status":200,"ts":1543242774796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"George Baker Selection","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":11,"lastName":"Brock","length":200.4371,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Morning Sky","status":200,"ts":1543242857796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Seru Giran","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":34,"lastName":"Rodriguez","length":230.81751,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Viernes 3 Am","status":200,"ts":1543243012796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"British Sea Power","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":12,"lastName":"Brock","length":196.8322,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"A Trip Out","status":200,"ts":1543243057796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":35,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"About","registration":1540511766796.0,"sessionId":900,"song":null,"status":200,"ts":1543243177796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Balkan Beat Box","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":36,"lastName":"Rodriguez","length":319.92118,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Adir Adirim (Featuring Victoria Hanna)","status":200,"ts":1543243242796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Premiers","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":13,"lastName":"Brock","length":134.81751,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Farmer John","status":200,"ts":1543243253796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Ivete Sangalo","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":14,"lastName":"Brock","length":221.23057,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"T\u00c3\u0083\u00c2\u00b4 Na Rua","status":200,"ts":1543243387796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Kanye West \/ GLC \/ Consequence","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":37,"lastName":"Rodriguez","length":324.20526,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Spaceship","status":200,"ts":1543243561796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Tommy Sands","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":15,"lastName":"Brock","length":140.12036,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Teenage Crush","status":200,"ts":1543243608796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":null,"auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":16,"lastName":"Brock","length":null,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"GET","page":"Downgrade","registration":1540852600796.0,"sessionId":381,"song":null,"status":200,"ts":1543243648796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Future Rock","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":17,"lastName":"Brock","length":239.90812,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Gears","status":200,"ts":1543243748796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Bersuit Vergarabat","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":38,"lastName":"Rodriguez","length":283.68934,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Y Llegar\u00c3\u0083\u00c2\u00a1 La Paz","status":200,"ts":1543243885796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Kanye West","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":18,"lastName":"Brock","length":311.92771,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Stronger","status":200,"ts":1543243987796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Pixies","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":39,"lastName":"Rodriguez","length":229.3024,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Where Is My Mind?","status":200,"ts":1543244168796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Fredrika Stahl","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":19,"lastName":"Brock","length":183.09179,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"I'Ll Win Your Heart","status":200,"ts":1543244298796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Vampire Weekend","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":40,"lastName":"Rodriguez","length":133.22404,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Bryn (Album)","status":200,"ts":1543244397796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":20,"lastName":"Brock","length":348.57751,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Undo","status":200,"ts":1543244481796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"White Rabbits","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":41,"lastName":"Rodriguez","length":214.22975,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Midnight And I","status":200,"ts":1543244530796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":943,"song":null,"status":307,"ts":1543244717796,"userAgent":null,"userId":""} {"artist":"La Coka Nostra","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":42,"lastName":"Rodriguez","length":210.52036,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Bang Bang (feat. Snoop Dogg)","status":200,"ts":1543244744796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Fredericks_ Goldman_ Jones","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":21,"lastName":"Brock","length":355.26485,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"On N'A Pas Chang\u00c3\u0083\u00c2\u00a9","status":200,"ts":1543244829796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":43,"lastName":"Rodriguez","length":201.63873,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Constellations","status":200,"ts":1543244954796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Josh Groban","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":22,"lastName":"Brock","length":272.37832,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"When You Say You Love Me (Album Version)","status":200,"ts":1543245184796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"System of a Down","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":23,"lastName":"Brock","length":169.89995,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Lonely Day","status":200,"ts":1543245456796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":943,"song":null,"status":200,"ts":1543245500796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":44,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Settings","registration":1540511766796.0,"sessionId":900,"song":null,"status":200,"ts":1543245612796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Kanka Feat. Brother Culture","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":24,"lastName":"Brock","length":293.40689,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Revolution","status":200,"ts":1543245625796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":45,"lastName":"Rodriguez","length":259.86567,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"My December","status":200,"ts":1543245706796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":959,"song":null,"status":200,"ts":1543245904796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sara Bareilles","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":25,"lastName":"Brock","length":233.37751,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Gravity","status":200,"ts":1543245918796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Marvin Gaye","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":46,"lastName":"Rodriguez","length":235.62404,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"I Want You","status":200,"ts":1543245965796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Toranja","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":26,"lastName":"Brock","length":120.21506,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Doce No Ch\u00c3\u0083\u00c2\u00a3o","status":200,"ts":1543246151796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Shinedown","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":47,"lastName":"Rodriguez","length":191.05914,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Cyanide Sweet Tooth Suicide (Album Version)","status":200,"ts":1543246200796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"the bird and the bee","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":27,"lastName":"Brock","length":165.642,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Again & Again","status":200,"ts":1543246271796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Morella's Forest","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":48,"lastName":"Rodriguez","length":243.01669,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Falling","status":200,"ts":1543246391796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":28,"lastName":"Brock","length":117.002,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Hell","status":200,"ts":1543246436796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Faith No More","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":186.14812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":959,"song":"Easy","status":200,"ts":1543246487796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bon Iver","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":29,"lastName":"Brock","length":238.49751,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Skinny Love","status":200,"ts":1543246553796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Hellogoodbye","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":49,"lastName":"Rodriguez","length":193.93261,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Shimmy Shimmy Quarter Turn (Take It Back To Square One)","status":200,"ts":1543246634796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Virus Syndicate","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":219.01016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":959,"song":"Vibrator","status":200,"ts":1543246673796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Plastilina Mosh","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":30,"lastName":"Brock","length":247.01342,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Al\u00c3\u0083\u00c2\u00b3","status":200,"ts":1543246791796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Rise Against","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":50,"lastName":"Rodriguez","length":242.25914,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Savior","status":200,"ts":1543246827796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Used","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":190.82404,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":959,"song":"Let It Bleed (Amended Album Version)","status":200,"ts":1543246892796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sonora Carruseles","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":31,"lastName":"Brock","length":223.65995,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Linda Cubana","status":200,"ts":1543247038796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Band Of Horses","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":51,"lastName":"Rodriguez","length":187.0624,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"The General Specific (Album)","status":200,"ts":1543247069796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"A Day To Remember","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":243.22567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":959,"song":"If It Means A Lot To You","status":200,"ts":1543247082796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Rammstein","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":52,"lastName":"Rodriguez","length":188.57751,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Feuer Frei","status":200,"ts":1543247256796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Angels and Airwaves","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":32,"lastName":"Brock","length":302.05342,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"The Gift","status":200,"ts":1543247261796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Circle Of Dead Children","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":30.82404,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":959,"song":"Grabbing N","status":200,"ts":1543247325796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Submersed","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":214.41261,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":959,"song":"Deny Me","status":200,"ts":1543247355796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Of Montreal","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":53,"lastName":"Rodriguez","length":265.56036,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Disconnect The Dots (LP Version)","status":200,"ts":1543247444796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Modern English","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":33,"lastName":"Brock","length":277.52444,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"I Melt With You","status":200,"ts":1543247563796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Elliott Smith","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":270.62812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":959,"song":"Twilight","status":200,"ts":1543247569796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cream","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":54,"lastName":"Rodriguez","length":298.23955,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"White Room","status":200,"ts":1543247709796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Blindside","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":192.20853,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":959,"song":"Pitiful (LP Version)","status":200,"ts":1543247839796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Benga","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":34,"lastName":"Brock","length":276.71465,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Benga's Off His Head","status":200,"ts":1543247840796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":"Rammstein","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":55,"lastName":"Rodriguez","length":188.57751,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":900,"song":"Feuer Frei","status":200,"ts":1543248007796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Timbaland \/ Mia","auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":35,"lastName":"Brock","length":234.52689,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540852600796.0,"sessionId":381,"song":"Come Around","status":200,"ts":1543248116796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":null,"auth":"Logged In","firstName":"Hayden","gender":"F","itemInSession":36,"lastName":"Brock","length":null,"level":"paid","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"Logout","registration":1540852600796.0,"sessionId":381,"song":null,"status":307,"ts":1543248117796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:30.0) Gecko\/20100101 Firefox\/30.0","userId":"72"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":37,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":381,"song":null,"status":200,"ts":1543248164796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":0,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540223723796.0,"sessionId":924,"song":null,"status":200,"ts":1543253636796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Les Savy Fav","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":1,"lastName":"Lynch","length":181.9424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":924,"song":"Bringing Us Down","status":200,"ts":1543253872796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":2,"lastName":"Lynch","length":201.79546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":924,"song":"Revelry","status":200,"ts":1543254053796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Hot Water Music","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":3,"lastName":"Lynch","length":156.62975,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":924,"song":"God Deciding","status":200,"ts":1543254254796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Blue States","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":4,"lastName":"Lynch","length":281.02485,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":924,"song":"Stereo 99","status":200,"ts":1543254410796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":5,"lastName":"Lynch","length":339.43465,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":924,"song":"Everywhere I Go","status":200,"ts":1543254691796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Trafik","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":6,"lastName":"Lynch","length":380.21179,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":924,"song":"Dirty Word","status":200,"ts":1543255030796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":933,"song":null,"status":200,"ts":1543256239796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":933,"song":null,"status":307,"ts":1543256240796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":933,"song":null,"status":200,"ts":1543256360796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"Palestine, TX","method":"GET","page":"Home","registration":1540685147796.0,"sessionId":938,"song":null,"status":200,"ts":1543256559796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Alice Cooper","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":1,"lastName":"Smith","length":155.42812,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":938,"song":"Under My Wheels (Live)","status":200,"ts":1543256579796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Settings","registration":1540794356796.0,"sessionId":933,"song":null,"status":200,"ts":1543256709796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"Save Settings","registration":1540794356796.0,"sessionId":933,"song":null,"status":307,"ts":1543256710796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Rolling Stones","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":2,"lastName":"Smith","length":271.49016,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":938,"song":"Angie (1993 Digital Remaster)","status":200,"ts":1543256734796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":933,"song":null,"status":200,"ts":1543256819796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Enrique Iglesias","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":3,"lastName":"Smith","length":264.202,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":938,"song":"Hero","status":200,"ts":1543257005796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Deadmau5","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":429.94893,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":933,"song":"Arguru","status":200,"ts":1543257066796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Aphex Twin","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":4,"lastName":"Smith","length":547.13424,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":938,"song":"Tha","status":200,"ts":1543257269796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Metric","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":286.24934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":933,"song":"Help I'm Alive","status":200,"ts":1543257495796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Warren Barfield","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":222.98077,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":933,"song":"Love Is Not A Fight","status":200,"ts":1543257781796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":5,"lastName":"Smith","length":283.92444,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":938,"song":"They Do_ They Don't","status":200,"ts":1543257816796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Akon","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":235.85914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":933,"song":"Lonely","status":200,"ts":1543258003796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Pixies","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":6,"lastName":"Smith","length":210.99057,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":938,"song":"Hey","status":200,"ts":1543258099796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":null,"auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":7,"lastName":"Smith","length":null,"level":"free","location":"Palestine, TX","method":"PUT","page":"Logout","registration":1540685147796.0,"sessionId":938,"song":null,"status":307,"ts":1543258100796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":8,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":938,"song":null,"status":200,"ts":1543258118796,"userAgent":null,"userId":""} {"artist":"Enya","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":179.90485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":933,"song":"To Go Beyond (II)","status":200,"ts":1543258238796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Steely Dan","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":273.89342,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":933,"song":"Rikki Don't Lose That Number","status":200,"ts":1543258417796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Salt-N-Pepa","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":207.62077,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":933,"song":"Push It","status":200,"ts":1543258690796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Five Finger Death Punch","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":174.13179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":933,"song":"Crossing Over","status":200,"ts":1543258897796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Die Mooskirchner","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":169.29914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":933,"song":"Frisch und g'sund","status":200,"ts":1543259071796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540306145796.0,"sessionId":953,"song":null,"status":200,"ts":1543261049796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Lynyrd Skynyrd","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Smith","length":216.60689,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":953,"song":"Sweet home Alabama","status":200,"ts":1543261099796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Kostia","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":2,"lastName":"Smith","length":281.10322,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":953,"song":"Secret Garden","status":200,"ts":1543261315796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":null,"auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":0,"lastName":"Rosales","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1541059521796.0,"sessionId":802,"song":null,"status":200,"ts":1543262967796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540306145796.0,"sessionId":966,"song":null,"status":200,"ts":1543269756796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"}
456.692593
552
0.699561
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":277.15873,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":961,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1543279932796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Jimi Hendrix","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":239.82975,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":961,"song":"Woodstock Inprovisation","status":200,"ts":1543280209796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Building 429","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":300.61669,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":961,"song":"Majesty (LP Version)","status":200,"ts":1543280448796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The B-52's","auth":"Logged In","firstName":"Gianna","gender":"F","itemInSession":0,"lastName":"Jones","length":321.54077,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540870346796.0,"sessionId":107,"song":"Love Shack","status":200,"ts":1543282396796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"38"} {"artist":"Die Mooskirchner","auth":"Logged In","firstName":"Gianna","gender":"F","itemInSession":1,"lastName":"Jones","length":169.29914,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540870346796.0,"sessionId":107,"song":"Frisch und g'sund","status":200,"ts":1543282717796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"38"} {"artist":"Carrie Underwood","auth":"Logged In","firstName":"Gianna","gender":"F","itemInSession":2,"lastName":"Jones","length":195.70893,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540870346796.0,"sessionId":107,"song":"Look At Me","status":200,"ts":1543282886796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"38"} {"artist":null,"auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":0,"lastName":"Ayala","length":null,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"GET","page":"Home","registration":1541007976796.0,"sessionId":586,"song":null,"status":200,"ts":1543290783796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":"No Te Va Gustar","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":0,"lastName":"Summers","length":246.43873,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":833,"song":"Ya Entend\u00c3\u0083\u00c2\u00ad","status":200,"ts":1543291714796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"The Velvet Underground \/ Nico","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":1,"lastName":"Summers","length":360.09751,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":833,"song":"All Tomorrow's Parties","status":200,"ts":1543291960796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Snoop Dogg \/ Jamie Foxx","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":2,"lastName":"Summers","length":179.35628,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":833,"song":"Psst!","status":200,"ts":1543292320796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Dixie Chicks","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":3,"lastName":"Summers","length":201.01179,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":833,"song":"There's Your Trouble","status":200,"ts":1543292499796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":null,"auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":4,"lastName":"Summers","length":null,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"GET","page":"Settings","registration":1540344794796.0,"sessionId":833,"song":null,"status":200,"ts":1543292542796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":5,"lastName":"Summers","length":189.28281,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"NextSong","registration":1540344794796.0,"sessionId":833,"song":"Given Up (Album Version)","status":200,"ts":1543292700796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":null,"auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":6,"lastName":"Summers","length":null,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"PUT","page":"Logout","registration":1540344794796.0,"sessionId":833,"song":null,"status":307,"ts":1543292701796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":7,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":833,"song":null,"status":200,"ts":1543292719796,"userAgent":null,"userId":""} {"artist":"Alice In Chains","auth":"Logged In","firstName":"Kevin","gender":"M","itemInSession":0,"lastName":"Arellano","length":239.35955,"level":"free","location":"Harrisburg-Carlisle, PA","method":"PUT","page":"NextSong","registration":1540006905796.0,"sessionId":934,"song":"Take Her Out","status":200,"ts":1543294087796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"66"} {"artist":null,"auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Home","registration":1541044398796.0,"sessionId":926,"song":null,"status":200,"ts":1543294532796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":1,"lastName":"Simpson","length":176.69179,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":926,"song":"My Boy Builds Coffins","status":200,"ts":1543294545796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Spoon","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":299.20608,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":968,"song":"The Mystery Zone","status":200,"ts":1543295971796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":null,"auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":0,"lastName":"Garrison","length":null,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"GET","page":"Home","registration":1540832693796.0,"sessionId":956,"song":null,"status":200,"ts":1543297181796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":894,"song":null,"status":200,"ts":1543298723796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":null,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"GET","page":"Home","registration":1540829025796.0,"sessionId":917,"song":null,"status":200,"ts":1543312040796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Alice In Chains","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":223.26812,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":917,"song":"Would?","status":200,"ts":1543312171796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Natalie Walker","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":2,"lastName":"Hess","length":191.84281,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":917,"song":"Colorblind","status":200,"ts":1543312394796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Traveling Wilburys","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":207.59465,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":940,"song":"End Of The Line","status":200,"ts":1543312620796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":null,"auth":"Logged In","firstName":"Brayden","gender":"M","itemInSession":0,"lastName":"Clark","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1541029236796.0,"sessionId":771,"song":null,"status":200,"ts":1543315088796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"41"} {"artist":null,"auth":"Logged In","firstName":"Stefany","gender":"F","itemInSession":0,"lastName":"White","length":null,"level":"free","location":"Lubbock, TX","method":"GET","page":"Home","registration":1540708070796.0,"sessionId":918,"song":null,"status":200,"ts":1543315988796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"83"} {"artist":"Cherokee","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":414.6673,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":960,"song":"Relax","status":200,"ts":1543318535796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"NOFX","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":1099.78077,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":960,"song":"The Decline","status":200,"ts":1543318949796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cameo","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":211.98322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":960,"song":"Word Up!","status":200,"ts":1543320048796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Natalia Lafourcade","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":0,"lastName":"Griffin","length":264.25424,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":879,"song":"Look Outside","status":200,"ts":1543320420796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"J Dilla","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":1,"lastName":"Griffin","length":232.46322,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":879,"song":"Won't Do","status":200,"ts":1543320684796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Sergio Mendes","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":2,"lastName":"Griffin","length":254.85016,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":879,"song":"Never Gonna Let You Go","status":200,"ts":1543320916796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Jarabe De Palo","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":3,"lastName":"Griffin","length":205.08689,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":879,"song":"En Lo Puro No Hay Futuro","status":200,"ts":1543321170796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Carrie Underwood","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":4,"lastName":"Griffin","length":257.88036,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":879,"song":"I Told You So","status":200,"ts":1543321375796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Enigma","auth":"Logged In","firstName":"Elijah","gender":"M","itemInSession":0,"lastName":"Davis","length":258.71628,"level":"free","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540772343796.0,"sessionId":138,"song":"Je T'aime Till My Dying Day","status":200,"ts":1543321596796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"5"} {"artist":"Kelly Clarkson","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":5,"lastName":"Griffin","length":221.09995,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":879,"song":"The Trouble With Love Is","status":200,"ts":1543321632796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Timbaland & Magoo","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":6,"lastName":"Griffin","length":279.7971,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":879,"song":"Put 'Em On","status":200,"ts":1543321853796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Wombats","auth":"Logged In","firstName":"Elijah","gender":"M","itemInSession":1,"lastName":"Davis","length":69.95546,"level":"free","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540772343796.0,"sessionId":138,"song":"Tales of Girls_ Boys and Marsupials (album version)","status":200,"ts":1543321854796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"5"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":7,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":879,"song":null,"status":200,"ts":1543321899796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Andrew Bird","auth":"Logged In","firstName":"Elijah","gender":"M","itemInSession":2,"lastName":"Davis","length":316.47302,"level":"free","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540772343796.0,"sessionId":138,"song":"Skin Is_ My","status":200,"ts":1543321923796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"5"} {"artist":null,"auth":"Logged In","firstName":"Elijah","gender":"M","itemInSession":3,"lastName":"Davis","length":null,"level":"free","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"Logout","registration":1540772343796.0,"sessionId":138,"song":null,"status":307,"ts":1543321924796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"5"} {"artist":"Colin James","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":8,"lastName":"Griffin","length":298.52689,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":879,"song":"Just Came Back","status":200,"ts":1543322132796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Los Wawanco","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":0,"lastName":"George","length":165.79873,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":871,"song":"La Casita Blanca","status":200,"ts":1543322317796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":1,"lastName":"George","length":null,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"Logout","registration":1541020249796.0,"sessionId":871,"song":null,"status":307,"ts":1543322318796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Dancing DJ's v Roxette","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":9,"lastName":"Griffin","length":370.78159,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":879,"song":"Fading Like A Flower (Extended Mix)","status":200,"ts":1543322430796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":871,"song":null,"status":200,"ts":1543322479796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":871,"song":null,"status":200,"ts":1543322493796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Help","registration":null,"sessionId":871,"song":null,"status":200,"ts":1543322555796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":138,"song":null,"status":200,"ts":1543322741796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":5,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":138,"song":null,"status":307,"ts":1543322742796,"userAgent":null,"userId":""} {"artist":"Robert Rich & Alio Die","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":10,"lastName":"Griffin","length":375.92771,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":879,"song":"Sirena","status":200,"ts":1543322800796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Gabin featuring China Moses","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":11,"lastName":"Griffin","length":249.36444,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":879,"song":"The Other Way Round (Feat. China Moses)","status":200,"ts":1543323175796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":12,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"Logout","registration":1541057188796.0,"sessionId":879,"song":null,"status":307,"ts":1543323176796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":13,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":879,"song":null,"status":200,"ts":1543323196796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":14,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":879,"song":null,"status":200,"ts":1543323198796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":15,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"About","registration":null,"sessionId":879,"song":null,"status":200,"ts":1543323357796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Elijah","gender":"M","itemInSession":6,"lastName":"Davis","length":null,"level":"free","location":"Detroit-Warren-Dearborn, MI","method":"GET","page":"Home","registration":1540772343796.0,"sessionId":138,"song":null,"status":200,"ts":1543324170796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"5"} {"artist":"Los Lobos","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":174.18404,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":978,"song":"La Bamba","status":200,"ts":1543325244796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Robert Pollard","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":202.91873,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":978,"song":"We All Got Out (of the Army)","status":200,"ts":1543325418796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"M\u00c3\u0083\u00c2\u00a5ns Zelmerl\u00c3\u0083\u00c2\u00b6w","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":2,"lastName":"Hess","length":206.96771,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":978,"song":"Brother Oh Brother","status":200,"ts":1543325620796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Shakira","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":3,"lastName":"Hess","length":192.70485,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":978,"song":"Did it Again","status":200,"ts":1543325826796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Showbread","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":4,"lastName":"Hess","length":297.58649,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":978,"song":"The Pig","status":200,"ts":1543326018796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":982,"song":null,"status":200,"ts":1543326994796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"DHT Feat. Edm\u00c3\u0083\u00c2\u00a9e","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":229.98159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":982,"song":"Listen To Your Heart","status":200,"ts":1543327964796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bersuit Vergarabat","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":212.40118,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":982,"song":"Yo Tomo","status":200,"ts":1543328193796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"La Roux","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":185.65179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":982,"song":"Quicksand","status":200,"ts":1543328405796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Conjure One","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":300.09424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":982,"song":"Center Of The Sun","status":200,"ts":1543328590796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Graham Colton","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":235.10159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":982,"song":"On Your Side","status":200,"ts":1543328890796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Starting Line","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":207.85587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":982,"song":"I'm Real","status":200,"ts":1543329125796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jimmy Eat World","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":385.802,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":982,"song":"Drugs Or Me","status":200,"ts":1543329332796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Pull Tiger Tail","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":239.882,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":982,"song":"Hurricanes","status":200,"ts":1543329717796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":224.67873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":982,"song":"Secrets","status":200,"ts":1543329956796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Hannah Montana","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":174.00118,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":982,"song":"The Best Of Both Worlds","status":200,"ts":1543330180796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":0,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":957,"song":null,"status":200,"ts":1543333544796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Ramses Shaffy","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":1,"lastName":"Jones","length":332.69506,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Laat Me.","status":200,"ts":1543333618796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Van Halen","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":2,"lastName":"Jones","length":228.33587,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Why Can't This Be Love (Remastered Version)","status":200,"ts":1543333950796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Method Man","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":195.97016,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":979,"song":"All I Need","status":200,"ts":1543334150796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Mando Diao","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":3,"lastName":"Jones","length":238.54975,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Down In The Past","status":200,"ts":1543334178796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Archies","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":166.16444,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":979,"song":"Sugar Sugar","status":200,"ts":1543334345796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":4,"lastName":"Jones","length":208.14322,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Apologize","status":200,"ts":1543334416796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Ensiferum","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":5,"lastName":"Jones","length":273.8673,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Lady In Black","status":200,"ts":1543334624796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Gold Panda","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":6,"lastName":"Jones","length":189.09995,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Win-san Western","status":200,"ts":1543334897796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Dixie Chicks","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":7,"lastName":"Jones","length":206.44526,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Tonight The Heartache's On Me","status":200,"ts":1543335086796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Ferry Corsten","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":8,"lastName":"Jones","length":466.46812,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Sublime","status":200,"ts":1543335292796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Energy 52","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":462.13179,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":946,"song":"Caf\u00c3\u0083\u00c2\u00a9 Del Mar","status":200,"ts":1543335380796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Babyshambles","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":9,"lastName":"Jones","length":206.49751,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Killamangiro","status":200,"ts":1543335758796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Michael Bubl\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":225.90649,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":946,"song":"Home (Album Version)","status":200,"ts":1543335842796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Steppenwolf","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":10,"lastName":"Jones","length":208.14322,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Born To Be Wild","status":200,"ts":1543335964796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Jean Michel Jarre","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":461.58322,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":946,"song":"oxygene 2","status":200,"ts":1543336067796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":11,"lastName":"Jones","length":348.57751,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Undo","status":200,"ts":1543336172796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Anberlin","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":12,"lastName":"Jones","length":203.02322,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Alexithymia","status":200,"ts":1543336520796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Metallica","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":13,"lastName":"Jones","length":515.21261,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Master Of Puppets","status":200,"ts":1543336723796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Imogen Heap","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":14,"lastName":"Jones","length":509.36118,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Hide & Seek","status":200,"ts":1543337238796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Crosby_ Stills & Nash","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":257.43628,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Long Time Gone (LP Version)","status":200,"ts":1543337486796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":15,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":957,"song":null,"status":200,"ts":1543337497796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540306145796.0,"sessionId":975,"song":null,"status":200,"ts":1543337582796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Nickel Creek","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":187.55873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Scotch & Chocolate","status":200,"ts":1543337743796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"MF Doom","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":16,"lastName":"Jones","length":296.72444,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Guinnesses (feat. Angelika & 4ize)","status":200,"ts":1543337747796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":989,"song":null,"status":200,"ts":1543337755796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Breaks Co-Op","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":199.73179,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":989,"song":"The Otherside (Acoustic Version)","status":200,"ts":1543337825796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"The Streets","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":208.90077,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"War Of The Sexes","status":200,"ts":1543337930796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Old 97's","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":17,"lastName":"Jones","length":231.28771,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Victoria (LP Version)","status":200,"ts":1543338043796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Martin O'Donnell And Michael Salvatori","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":185.80853,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Reclaimer","status":200,"ts":1543338138796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kate Voegele","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":18,"lastName":"Jones","length":248.31955,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"It's Only Life","status":200,"ts":1543338274796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":220.89098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Somebody To Love","status":200,"ts":1543338323796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Devotchka","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":19,"lastName":"Jones","length":225.09669,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Head Honcho","status":200,"ts":1543338522796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Silversun Pickups","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":340.53179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Three Seed","status":200,"ts":1543338543796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Animal Collective","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":20,"lastName":"Jones","length":164.77995,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Winter Wonderland","status":200,"ts":1543338747796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Dinosaur Jr.","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":198.53016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Does It Float","status":200,"ts":1543338883796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Iam","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":21,"lastName":"Jones","length":287.92118,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Contrat De Conscience","status":200,"ts":1543338911796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Sam Sparro","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":284.70812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Pocket","status":200,"ts":1543339081796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Ethiopians","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":22,"lastName":"Jones","length":170.1873,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Train To Skaville","status":200,"ts":1543339198796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Leonard Cohen","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":365.94893,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Dance Me To The End Of Love","status":200,"ts":1543339365796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Herman's Hermits","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":23,"lastName":"Jones","length":155.42812,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"I'm Into Something Good","status":200,"ts":1543339368796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Seeed","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":24,"lastName":"Jones","length":207.59465,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Tide Is High (Es Geht Auch Anders Mix)","status":200,"ts":1543339523796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Future Rock","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":239.90812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Gears","status":200,"ts":1543339730796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Three Drives","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":25,"lastName":"Jones","length":411.6371,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Greece 2000","status":200,"ts":1543339730796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Eminem","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":283.55873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Deja Vu","status":200,"ts":1543339969796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":26,"lastName":"Jones","length":230.94812,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"It's Just A Thought","status":200,"ts":1543340141796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":219.66322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1543340252796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Kooks","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":27,"lastName":"Jones","length":98.16771,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Seaside","status":200,"ts":1543340371796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Yazoo","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":28,"lastName":"Jones","length":178.99057,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Don't Go (Live)","status":200,"ts":1543340469796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Hans Zimmer_ James Newton Howard","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":455.47057,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Macrotus","status":200,"ts":1543340471796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Paul Cardall","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":29,"lastName":"Jones","length":222.87628,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Scarborough Fair","status":200,"ts":1543340647796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Aretha Franklin","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":30,"lastName":"Jones","length":183.90159,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Hello Sunshine","status":200,"ts":1543340869796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Muse","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":209.50159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Supermassive Black Hole (Twilight Soundtrack Version)","status":200,"ts":1543340926796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Coldplay","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":31,"lastName":"Jones","length":298.762,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Shiver","status":200,"ts":1543341052796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":32,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"Logout","registration":1541062818796.0,"sessionId":957,"song":null,"status":307,"ts":1543341053796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Eric Clapton","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":271.80363,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Tears In Heaven","status":200,"ts":1543341135796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":965,"song":null,"status":200,"ts":1543341216796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":33,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":957,"song":null,"status":200,"ts":1543341216796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":34,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":957,"song":null,"status":200,"ts":1543341238796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":35,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":957,"song":null,"status":307,"ts":1543341239796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":36,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":957,"song":null,"status":200,"ts":1543341335796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Kate Winslet","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":37,"lastName":"Jones","length":106.73587,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"What If (Film Version)","status":200,"ts":1543341350796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Roadrunner United","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":285.02159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"The Enemy (Album Version)","status":200,"ts":1543341406796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Flogging Molly","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":38,"lastName":"Jones","length":260.75383,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Punch Drunk Grinning Soul","status":200,"ts":1543341456796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Apocalyptica","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":206.15791,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Quutamo","status":200,"ts":1543341691796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Blind Melon","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":39,"lastName":"Jones","length":214.72608,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Mouthful Of Cavities","status":200,"ts":1543341716796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Killswitch Engage","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":17,"lastName":"Cuevas","length":254.45832,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"In A Dead World (Album Version)","status":200,"ts":1543341897796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Charlie Wilson featuring Snoop Dogg","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":40,"lastName":"Jones","length":231.70567,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Let It Out","status":200,"ts":1543341930796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":18,"lastName":"Cuevas","length":229.61587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":987,"song":"Let's Get It Started","status":200,"ts":1543342151796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":19,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"Logout","registration":1540940782796.0,"sessionId":987,"song":null,"status":307,"ts":1543342152796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Coldplay","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":41,"lastName":"Jones","length":139.12771,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Don't Panic","status":200,"ts":1543342161796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Tori Amos Featuring Damien Rice","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":42,"lastName":"Jones","length":215.82322,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"The Power of Orange Knickers","status":200,"ts":1543342300796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Abba","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":43,"lastName":"Jones","length":213.05424,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Summer Night City","status":200,"ts":1543342515796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Blu Cantrell Featuring Foxy Brown","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":44,"lastName":"Jones","length":250.69669,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Hit 'Em Up Style (Oops!)","status":200,"ts":1543342728796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Keyshia Cole \/ T.I. \/ Missy Elliott \/ Young Dro","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":45,"lastName":"Jones","length":220.08118,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Let It Go","status":200,"ts":1543342978796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Maroon 5","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":46,"lastName":"Jones","length":152.842,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Can't Stop","status":200,"ts":1543343198796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Angels and Airwaves","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":47,"lastName":"Jones","length":302.05342,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"The Gift","status":200,"ts":1543343350796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Silversun Pickups","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":48,"lastName":"Jones","length":348.23791,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Lazy Eye [Jason Bentley Remix]","status":200,"ts":1543343652796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":20,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":987,"song":null,"status":200,"ts":1543343704796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":49,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Settings","registration":1541062818796.0,"sessionId":957,"song":null,"status":200,"ts":1543343875796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":50,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":957,"song":null,"status":200,"ts":1543343969796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"65daysofstatic","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":264.98567,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Drove Through Ghosts to Get Here","status":200,"ts":1543343976796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Los Abuelos De La Nada","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":51,"lastName":"Jones","length":122.27873,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Se Me Olvid\u00c3\u0083\u00c2\u00b3 Que Te Olvid\u00c3\u0083\u00c2\u00a9","status":200,"ts":1543344000796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"STRATOVARIUS","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":52,"lastName":"Jones","length":442.06975,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Soul Of A Vagabond","status":200,"ts":1543344122796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Young Money featuring Lloyd","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":196.33587,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"BedRock (Radio Edit) (feat.Lloyd)","status":200,"ts":1543344240796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Human League","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":225.17506,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"(Keep Feeling) Fascination (2003 Digital Remaster)","status":200,"ts":1543344436796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Enya","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":53,"lastName":"Jones","length":185.7824,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Aldebaran","status":200,"ts":1543344564796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Alceu Valen\u00c3\u0083\u00c2\u00a7a","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":3,"lastName":"Rodriguez","length":176.56118,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Eu Te Amo","status":200,"ts":1543344661796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Nickel Creek","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":54,"lastName":"Jones","length":225.69751,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"In The House Of Tom Bombadil","status":200,"ts":1543344749796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Brantley","gender":"M","itemInSession":0,"lastName":"West","length":null,"level":"free","location":"Portland-Vancouver-Hillsboro, OR-WA","method":"GET","page":"Home","registration":1541056614796.0,"sessionId":270,"song":null,"status":200,"ts":1543344772796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"28"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Brantley","gender":"M","itemInSession":1,"lastName":"West","length":208.95302,"level":"free","location":"Portland-Vancouver-Hillsboro, OR-WA","method":"PUT","page":"NextSong","registration":1541056614796.0,"sessionId":270,"song":"Crawling (Album Version)","status":200,"ts":1543344778796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"28"} {"artist":"Matisyahu","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":4,"lastName":"Rodriguez","length":222.37995,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"King Without A Crown","status":200,"ts":1543344837796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bryn Terfel \/ Berliner Philharmoniker \/ Claudio Abbado","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":55,"lastName":"Jones","length":967.36608,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Wotan's Farewell & Magic Fire Music","status":200,"ts":1543344974796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Jens Lekman","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":5,"lastName":"Rodriguez","length":210.46812,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Someone To Share My Life With","status":200,"ts":1543345059796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Propellerheads","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":6,"lastName":"Rodriguez","length":239.3073,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Take California","status":200,"ts":1543345269796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":286.6673,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Human After All (SebastiAn Remix )","status":200,"ts":1543345342796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Edward Sharpe & The Magnetic Zeros","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":7,"lastName":"Rodriguez","length":306.31138,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Home","status":200,"ts":1543345508796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Feeling","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":227.36934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"I Want You Now","status":200,"ts":1543345628796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Crystal Castles","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":8,"lastName":"Rodriguez","length":186.38322,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Untrust us","status":200,"ts":1543345814796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":152.52853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Busted","status":200,"ts":1543345855796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Timbaland \/ Keri Hilson \/ D.O.E.","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":56,"lastName":"Jones","length":179.25179,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"The Way I Are","status":200,"ts":1543345941796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Oliver Koletzki","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":9,"lastName":"Rodriguez","length":609.48853,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Nascita Of The Monsters","status":200,"ts":1543346000796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Josh Groban","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":152.0322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Lullaby [With Ladysmith Black Mambazo] (Album Version)","status":200,"ts":1543346007796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Moonspell","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":57,"lastName":"Jones","length":293.642,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Hers is the twilight","status":200,"ts":1543346120796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":252.21179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1543346159796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Silverchair","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":267.88526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Tomorrow","status":200,"ts":1543346411796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Blood Red Shoes","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":58,"lastName":"Jones","length":186.90567,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Don't Ask","status":200,"ts":1543346413796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Kurd Maverick","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":59,"lastName":"Jones","length":480.46975,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Let's Work","status":200,"ts":1543346599796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Deadmau5","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":10,"lastName":"Rodriguez","length":429.94893,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Arguru","status":200,"ts":1543346609796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Usher Featuring Lil' Jon & Ludacris","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":11,"lastName":"Rodriguez","length":250.38322,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Yeah!","status":200,"ts":1543347038796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":992,"song":null,"status":200,"ts":1543347060796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Aztext","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":60,"lastName":"Jones","length":259.21261,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Learn to Talk","status":200,"ts":1543347079796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Rey Ruiz","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":12,"lastName":"Rodriguez","length":301.87057,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Por Amarte As\u00c3\u0083\u00c2\u00ad","status":200,"ts":1543347288796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":61,"lastName":"Jones","length":348.57751,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Undo","status":200,"ts":1543347338796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"LeAnn Rimes","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":13,"lastName":"Rodriguez","length":217.25995,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Probably Wouldn't Be This Way (Dann Huff remix)","status":200,"ts":1543347589796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Jagged Edge","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":62,"lastName":"Jones","length":195.21261,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Addicted To Your Love","status":200,"ts":1543347686796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":183.53587,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Rock The House (Radio Edit)","status":200,"ts":1543347767796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":14,"lastName":"Rodriguez","length":193.14893,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Used To Love Her","status":200,"ts":1543347806796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Verdena","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":63,"lastName":"Jones","length":241.162,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Phantastica","status":200,"ts":1543347881796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Angus & Julia Stone","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":218.8273,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Soldier","status":200,"ts":1543347950796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Tegan And Sara","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":15,"lastName":"Rodriguez","length":180.29669,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Relief Next To Me (Album Version)","status":200,"ts":1543347999796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":64,"lastName":"Jones","length":348.57751,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Undo","status":200,"ts":1543348122796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Andrew Gold","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":282.01751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Thank You for Being a Friend","status":200,"ts":1543348168796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Platero Y Tu","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":16,"lastName":"Rodriguez","length":133.61587,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Imanol","status":200,"ts":1543348179796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"My Chemical Romance","auth":"Logged In","firstName":"Magdalene","gender":"F","itemInSession":0,"lastName":"Herman","length":311.11791,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540766630796.0,"sessionId":707,"song":"Welcome To The Black Parade (Album Version)","status":200,"ts":1543348301796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"77"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":17,"lastName":"Rodriguez","length":220.89098,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Somebody To Love","status":200,"ts":1543348312796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bl\u00c3\u0083\u00c2\u00b8f","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":294.29506,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Aanzoek Zonder Ringen (met Kodo)","status":200,"ts":1543348450796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Avenged Sevenfold","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":65,"lastName":"Jones","length":312.11057,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Bat Country (Album Version)","status":200,"ts":1543348470796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"KMC Feat. Dhany","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":18,"lastName":"Rodriguez","length":483.81342,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"I Feel So Fine ","status":200,"ts":1543348532796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Magdalene","gender":"F","itemInSession":1,"lastName":"Herman","length":201.79546,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540766630796.0,"sessionId":707,"song":"Revelry","status":200,"ts":1543348612796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"77"} {"artist":"Faith No More","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":257.802,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Midlife Crisis","status":200,"ts":1543348744796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":66,"lastName":"Jones","length":197.45914,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Him","status":200,"ts":1543348782796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":67,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Settings","registration":1541062818796.0,"sessionId":957,"song":null,"status":200,"ts":1543348788796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Framing Hanley","auth":"Logged In","firstName":"Magdalene","gender":"F","itemInSession":2,"lastName":"Herman","length":230.08608,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540766630796.0,"sessionId":707,"song":"Alone In This Bed (Capeside)","status":200,"ts":1543348813796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"77"} {"artist":"Andrew Jackson Jihad","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":68,"lastName":"Jones","length":74.97098,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Brave as a Noun","status":200,"ts":1543348979796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Twista","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":223.03302,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Girl Tonite [Featuring Trey Songz] [Explicit Album Version]","status":200,"ts":1543349001796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Sisqo","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":19,"lastName":"Rodriguez","length":253.49179,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Thong Song","status":200,"ts":1543349015796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Underworld","auth":"Logged In","firstName":"Magdalene","gender":"F","itemInSession":3,"lastName":"Herman","length":158.4322,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540766630796.0,"sessionId":707,"song":"To Heal","status":200,"ts":1543349043796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"77"} {"artist":"Paramore","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":69,"lastName":"Jones","length":267.65016,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"The Only Exception (Album Version)","status":200,"ts":1543349053796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Train","auth":"Logged In","firstName":"Magdalene","gender":"F","itemInSession":4,"lastName":"Herman","length":216.76363,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540766630796.0,"sessionId":707,"song":"Hey_ Soul Sister","status":200,"ts":1543349201796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"77"} {"artist":"Die Mooskirchner","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":169.29914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Frisch und g'sund","status":200,"ts":1543349224796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Ron Carter","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":20,"lastName":"Rodriguez","length":497.13587,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"I CAN'T GET STARTED","status":200,"ts":1543349268796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bo Kaspers Orkester","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":70,"lastName":"Jones","length":259.36934,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Undantag","status":200,"ts":1543349320796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Kid Cudi \/ MGMT \/ Ratatat","auth":"Logged In","firstName":"Magdalene","gender":"F","itemInSession":5,"lastName":"Herman","length":295.67955,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540766630796.0,"sessionId":707,"song":"Pursuit Of Happiness (nightmare)","status":200,"ts":1543349417796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"77"} {"artist":"Bacilos","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":71,"lastName":"Jones","length":307.51302,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Viejo","status":200,"ts":1543349579796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":72,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Downgrade","registration":1541062818796.0,"sessionId":957,"song":null,"status":200,"ts":1543349625796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Alejandro Sanz","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":21,"lastName":"Rodriguez","length":277.2371,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Y solo se me ocurre amarte (Unplugged)","status":200,"ts":1543349765796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"UNKLE","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":73,"lastName":"Jones","length":295.54893,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Burn My Shadow","status":200,"ts":1543349886796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"the bird and the bee","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":22,"lastName":"Rodriguez","length":225.17506,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"My Love","status":200,"ts":1543350042796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"TRUSTcompany","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":0,"lastName":"Johnson","length":194.2722,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":773,"song":"Take It All","status":200,"ts":1543350062796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"Pixies","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":74,"lastName":"Jones","length":229.3024,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Where Is My Mind?","status":200,"ts":1543350181796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Settings","registration":1540794356796.0,"sessionId":992,"song":null,"status":200,"ts":1543350238796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Faith No More","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":23,"lastName":"Rodriguez","length":249.86077,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Last Cup Of Sorrow","status":200,"ts":1543350267796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Big Tymers","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":75,"lastName":"Jones","length":289.95873,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Rocky","status":200,"ts":1543350410796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Darkness","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":24,"lastName":"Rodriguez","length":217.05098,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"I Believe In A Thing Called Love","status":200,"ts":1543350516796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":993,"song":null,"status":200,"ts":1543350635796,"userAgent":null,"userId":""} {"artist":"D Black","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":76,"lastName":"Jones","length":261.14567,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":957,"song":"Mais E Mais Amor","status":200,"ts":1543350699796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Craig Mack","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":25,"lastName":"Rodriguez","length":218.04363,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Flava In Your Ear","status":200,"ts":1543350733796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"DAVE MATTHEWS BAND","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":71.81016,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Grux","status":200,"ts":1543350744796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Sugar Pie DeSanto","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":169.50812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Soulful Dress","status":200,"ts":1543350815796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mickie Krause","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":26,"lastName":"Rodriguez","length":204.17261,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Orange Tr\u00c3\u0083\u00c2\u00a4gt Nur Die M\u00c3\u0083\u00c2\u00bcllabfuhr (Go West)","status":200,"ts":1543350951796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Mikel Erentxun","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":178.83383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Frases Mudas","status":200,"ts":1543350984796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Sigur R\u00c3\u0083\u00c2\u00b3s","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":27,"lastName":"Rodriguez","length":333.63546,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Gong","status":200,"ts":1543351155796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Two Door Cinema Club","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":18,"lastName":"Levine","length":190.56281,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"You Are Not Stubborn","status":200,"ts":1543351162796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Josh Turner","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":19,"lastName":"Levine","length":208.84853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Firecracker","status":200,"ts":1543351352796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"El Gran Combo De Puerto Rico","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":28,"lastName":"Rodriguez","length":226.89914,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Sin Salsa No Hay Para\u00c3\u0083\u00c2\u00adso","status":200,"ts":1543351488796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":20,"lastName":"Levine","length":156.18567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Heavy Soul ","status":200,"ts":1543351560796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Muse","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":29,"lastName":"Rodriguez","length":185.93914,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Yes Please","status":200,"ts":1543351714796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Rivers Cuomo","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":21,"lastName":"Levine","length":219.48036,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"The World We Love So Much","status":200,"ts":1543351716796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Man Man","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":30,"lastName":"Rodriguez","length":222.45832,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Van Helsing Boombox","status":200,"ts":1543351899796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Four Tet","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":22,"lastName":"Levine","length":276.76689,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Untangle","status":200,"ts":1543351935796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Usher featuring will.i.am","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":31,"lastName":"Rodriguez","length":395.72853,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"OMG","status":200,"ts":1543352121796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Grateful Dead","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":23,"lastName":"Levine","length":351.9473,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Peggy-O [Studio Outtake]","status":200,"ts":1543352211796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Rilo Kiley","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":32,"lastName":"Rodriguez","length":270.99383,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"I Never (Album Version)","status":200,"ts":1543352516796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Leonard Cohen","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":24,"lastName":"Levine","length":267.67628,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"I'm Your Man","status":200,"ts":1543352562796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":33,"lastName":"Rodriguez","length":191.55546,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Love Me","status":200,"ts":1543352786796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Olivier Darock","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":25,"lastName":"Levine","length":391.10485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Miss You","status":200,"ts":1543352829796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Anjulie","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":34,"lastName":"Rodriguez","length":187.76771,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"Addicted2Me","status":200,"ts":1543352977796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Rilo Kiley","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":35,"lastName":"Rodriguez","length":322.42893,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":969,"song":"A Man\/Me\/Then Jim (Album Version)","status":200,"ts":1543353164796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":26,"lastName":"Levine","length":258.55955,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Cosmic Love","status":200,"ts":1543353220796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":27,"lastName":"Levine","length":213.28934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Harder Better Faster Stronger (Alive Radio Edit 2007)","status":200,"ts":1543353478796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"R. Kelly","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":297.37751,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":935,"song":"Your Body's Callin'","status":200,"ts":1543353612796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Erykah Badu","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":28,"lastName":"Levine","length":366.65424,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Fall In Love (your funeral)","status":200,"ts":1543353691796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"C.J. Lewis","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":1,"lastName":"Hicks","length":201.27302,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":935,"song":"Sweets For My Sweet","status":200,"ts":1543353909796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Modest Mouse","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":29,"lastName":"Levine","length":190.35383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Here It Comes","status":200,"ts":1543354057796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Lil Wayne \/ Bobby Valentino \/ Kidd Kidd","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":30,"lastName":"Levine","length":286.95465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Mrs. Officer","status":200,"ts":1543354247796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Pantera","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":31,"lastName":"Levine","length":239.0722,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Becoming [Live Version]","status":200,"ts":1543354533796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":32,"lastName":"Levine","length":252.52526,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"DOA","status":200,"ts":1543354772796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jeremih","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":33,"lastName":"Levine","length":220.55138,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"My Ride","status":200,"ts":1543355024796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Charttraxx Karaoke","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":34,"lastName":"Levine","length":225.17506,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Fireflies","status":200,"ts":1543355244796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Nirvana","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":35,"lastName":"Levine","length":186.48771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Breed","status":200,"ts":1543355469796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kanye West","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":36,"lastName":"Levine","length":311.84934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Stronger","status":200,"ts":1543355655796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kiuas","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":37,"lastName":"Levine","length":265.24689,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"The New Chapter","status":200,"ts":1543355966796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Wet Wet Wet","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":38,"lastName":"Levine","length":237.71383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Love Is All Around","status":200,"ts":1543356231796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Michael Bubl\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":39,"lastName":"Levine","length":199.20934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Come Fly With Me (Album Version)","status":200,"ts":1543356468796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jody McBrayer","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":40,"lastName":"Levine","length":247.19628,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"To Ever Live Without Me","status":200,"ts":1543356667796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"No Mercy","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":41,"lastName":"Levine","length":240.8224,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Please Don't Go","status":200,"ts":1543356914796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":42,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Downgrade","registration":1540794356796.0,"sessionId":992,"song":null,"status":200,"ts":1543357643796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Coldplay","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":47.64689,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":876,"song":"Postcards From Far Away","status":200,"ts":1543357993796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Philippe Rochard","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":1,"lastName":"Gonzalez","length":360.51546,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":876,"song":"Crumpshit","status":200,"ts":1543358040796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Samy Deluxe","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":43,"lastName":"Levine","length":238.36689,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Intro","status":200,"ts":1543358159796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Method Man","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":44,"lastName":"Levine","length":196.75383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Method Man","status":200,"ts":1543358397796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"America","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":2,"lastName":"Gonzalez","length":219.19302,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":876,"song":"Love & Leaving","status":200,"ts":1543358400796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Pet Shop Boys With Dusty Springfield","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":45,"lastName":"Levine","length":262.19057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"What Have I Done To Deserve This? (2001 Digital Remaster)","status":200,"ts":1543358593796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Paramore","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":3,"lastName":"Gonzalez","length":267.65016,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":876,"song":"The Only Exception (Album Version)","status":200,"ts":1543358619796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":null,"auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":4,"lastName":"Gonzalez","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540492941796.0,"sessionId":876,"song":null,"status":200,"ts":1543358660796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"The Offspring","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":46,"lastName":"Levine","length":239.93424,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"We Are One","status":200,"ts":1543358855796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":5,"lastName":"Gonzalez","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Settings","registration":1540492941796.0,"sessionId":876,"song":null,"status":200,"ts":1543358917796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Markus Schulz Feat. Departure","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":6,"lastName":"Gonzalez","length":543.58159,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":876,"song":"Cause You Know","status":200,"ts":1543358958796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Lupe Fiasco feat. Nikki Jean","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":47,"lastName":"Levine","length":242.49424,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Hip-Hop Saved My Life (feat. Nikki Jean) (Explicit Album Version)","status":200,"ts":1543359094796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"ISRAEL & NEW BREED","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":48,"lastName":"Levine","length":469.52444,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"If Not For Your Grace","status":200,"ts":1543359336796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":7,"lastName":"Gonzalez","length":80.87465,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":876,"song":"Bird Song Intro","status":200,"ts":1543359501796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Crash Romeo","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":49,"lastName":"Levine","length":170.84036,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Actions not words","status":200,"ts":1543359805796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Royksopp","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":50,"lastName":"Levine","length":163.65669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Happy Up Here","status":200,"ts":1543359975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Cage The Elephant","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":51,"lastName":"Levine","length":241.162,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"In One Ear","status":200,"ts":1543360138796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Unwinding Hours","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":52,"lastName":"Levine","length":301.50485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"There Are Worse Things Than Being Alone","status":200,"ts":1543360379796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Shakira","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":53,"lastName":"Levine","length":159.05914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"La Pared","status":200,"ts":1543360680796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Vader","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":54,"lastName":"Levine","length":245.86404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Fight Fire With Fire","status":200,"ts":1543360839796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Combichrist","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":336.14322,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":958,"song":"red signal","status":200,"ts":1543360879796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Good Old War","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":55,"lastName":"Levine","length":166.03383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Just Another Day","status":200,"ts":1543361084796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Regina Spektor","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":56,"lastName":"Levine","length":122.43546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Baobabs (Bonus Album Version)","status":200,"ts":1543361250796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Cartola","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":57,"lastName":"Levine","length":208.92689,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Sala De Recep\u00c3\u0083\u00c2\u00a7\u00c3\u0083\u00c2\u00a3o","status":200,"ts":1543361372796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Offspring","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":58,"lastName":"Levine","length":175.04608,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Not the One (Album Version)","status":200,"ts":1543361580796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Nirvana","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":59,"lastName":"Levine","length":257.01832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Lithium","status":200,"ts":1543361755796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Radio Dept.","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":60,"lastName":"Levine","length":163.36934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Where Damage Isn't Already Done","status":200,"ts":1543362012796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Ol\u00c3\u0083\u00c2\u00a9 Ol\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":61,"lastName":"Levine","length":247.87546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Con s\u00c3\u0083\u00c2\u00b3lo una mirada","status":200,"ts":1543362175796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Lady GaGa","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":62,"lastName":"Levine","length":274.18077,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Alejandro","status":200,"ts":1543362422796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Temper Trap","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":63,"lastName":"Levine","length":275.40853,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Fools","status":200,"ts":1543362696796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Avett Brothers","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":64,"lastName":"Levine","length":244.29669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Go To Sleep","status":200,"ts":1543362971796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"}
466.412541
614
0.699276
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Mitch Ryder & The Detroit Wheels","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":65,"lastName":"Levine","length":205.03465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Jenny Take A Ride (LP Version)","status":200,"ts":1543363215796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Spill Canvas","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":66,"lastName":"Levine","length":358.03383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"The TIde (LP Version)","status":200,"ts":1543363420796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mogwai","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":67,"lastName":"Levine","length":571.19302,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Two Rights Make One Wrong","status":200,"ts":1543363778796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Spor","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":68,"lastName":"Levine","length":380.3424,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Way Of The Samurai","status":200,"ts":1543364349796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"DJ Dizzy","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":69,"lastName":"Levine","length":221.1522,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Sexy Bitch","status":200,"ts":1543364729796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Erik Hassle","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":70,"lastName":"Levine","length":183.43138,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":992,"song":"Hurtful","status":200,"ts":1543364950796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":952,"song":null,"status":200,"ts":1543365211796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":952,"song":null,"status":307,"ts":1543365212796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":952,"song":null,"status":200,"ts":1543365223796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":71,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":992,"song":null,"status":200,"ts":1543365724796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":null,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"GET","page":"Home","registration":1540266185796.0,"sessionId":932,"song":null,"status":200,"ts":1543368722796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":964,"song":null,"status":307,"ts":1543369200796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":1,"lastName":"Smith","length":null,"level":"free","location":"Palestine, TX","method":"GET","page":"Home","registration":1540685147796.0,"sessionId":964,"song":null,"status":200,"ts":1543369248796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Phoenix","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":2,"lastName":"Smith","length":207.15057,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":964,"song":"Holdin' On Together","status":200,"ts":1543369249796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":3,"lastName":"Smith","length":175.43791,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":964,"song":"Mardy Bum","status":200,"ts":1543369456796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"tobyMac","auth":"Logged In","firstName":"Braden","gender":"M","itemInSession":0,"lastName":"Parker","length":229.69424,"level":"free","location":"Youngstown-Warren-Boardman, OH-PA","method":"PUT","page":"NextSong","registration":1540999292796.0,"sessionId":801,"song":"Burn For You","status":200,"ts":1543377306796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"74"} {"artist":null,"auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":0,"lastName":"Johnson","length":null,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"GET","page":"Home","registration":1541081807796.0,"sessionId":996,"song":null,"status":200,"ts":1543381987796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"Jadakiss \/ Swizz Beatz \/ OJ Da Juiceman","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":1,"lastName":"Johnson","length":191.84281,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":996,"song":"Who's Real","status":200,"ts":1543382018796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":0,"lastName":"Garrison","length":219.66322,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"PUT","page":"NextSong","registration":1540832693796.0,"sessionId":976,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1543386015796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":"The White Stripes","auth":"Logged In","firstName":"Tucker","gender":"M","itemInSession":1,"lastName":"Garrison","length":160.31302,"level":"free","location":"Oxnard-Thousand Oaks-Ventura, CA","method":"PUT","page":"NextSong","registration":1540832693796.0,"sessionId":976,"song":"Blue Orchid","status":200,"ts":1543386234796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"40"} {"artist":"Plus One","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":0,"lastName":"Benson","length":231.8624,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"You (w\/o Organ Version)","status":200,"ts":1543389090796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Counting Crows","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":1,"lastName":"Benson","length":272.79628,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Mr. Jones","status":200,"ts":1543389321796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Pickin' On Series","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":0,"lastName":"Scott","length":199.41832,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":922,"song":"A Different City","status":200,"ts":1543389451796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Eminem","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":2,"lastName":"Benson","length":320.83546,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Hailie's Song","status":200,"ts":1543389593796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Heart","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":1,"lastName":"Scott","length":270.18404,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":922,"song":"Wild Child","status":200,"ts":1543389650796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":null,"auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":2,"lastName":"Scott","length":null,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"Logout","registration":1540872073796.0,"sessionId":922,"song":null,"status":307,"ts":1543389651796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":922,"song":null,"status":200,"ts":1543389661796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":4,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":922,"song":null,"status":307,"ts":1543389662796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":5,"lastName":"Scott","length":null,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"GET","page":"Home","registration":1540872073796.0,"sessionId":922,"song":null,"status":200,"ts":1543389697796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Sergio Dalma","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":3,"lastName":"Benson","length":269.45261,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"La Vida Pasa","status":200,"ts":1543389913796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"AFI","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":6,"lastName":"Scott","length":256.86159,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":922,"song":"The Interview","status":200,"ts":1543389920796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Four Year Strong","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":4,"lastName":"Benson","length":199.88853,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"This Body Pays The Bill$","status":200,"ts":1543390182796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Two Door Cinema Club","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":5,"lastName":"Benson","length":168.09751,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Undercover Martyn","status":200,"ts":1543390381796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Jim Brickman;Herb Alpert;Bruce Upchurch","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":6,"lastName":"Benson","length":199.54893,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Rendezvous","status":200,"ts":1543390549796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Dominique A","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":7,"lastName":"Benson","length":153.20771,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Le Courage Des Oiseaux","status":200,"ts":1543390748796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Pure Ecstasy","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":8,"lastName":"Benson","length":238.94159,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Voices","status":200,"ts":1543390901796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":9,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"Home","registration":1540907087796.0,"sessionId":887,"song":null,"status":200,"ts":1543390911796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Juanes","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":10,"lastName":"Benson","length":211.77424,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Bailala","status":200,"ts":1543391139796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Fountains Of Wayne","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":11,"lastName":"Benson","length":197.40689,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Stacy's Mom","status":200,"ts":1543391350796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Beastie Boys","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":12,"lastName":"Benson","length":211.722,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Unite (2009 Digital Remaster)","status":200,"ts":1543391547796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":13,"lastName":"Benson","length":211.01669,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Tighten Up","status":200,"ts":1543391758796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"LMFAO","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":14,"lastName":"Benson","length":183.74485,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Yes","status":200,"ts":1543391969796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"David Bowie","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":15,"lastName":"Benson","length":174.41914,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Sorrow (1997 Digital Remaster)","status":200,"ts":1543392152796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Ben Folds","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":16,"lastName":"Benson","length":254.17098,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"The Ascent Of Stan","status":200,"ts":1543392326796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Kate Voegele","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":17,"lastName":"Benson","length":222.64118,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"One Way Or Another","status":200,"ts":1543392580796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Relient K","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":18,"lastName":"Benson","length":238.94159,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Jefferson Aeroplane [Demo]","status":200,"ts":1543392802796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Someone Still Loves You Boris Yeltsin","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":19,"lastName":"Benson","length":97.35791,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Yr Broom (Cd)","status":200,"ts":1543393040796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Luis Miguel","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":20,"lastName":"Benson","length":256.13016,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Suena (\"Some Day\" end title song \"The Hunchback of Notre Dame\")","status":200,"ts":1543393137796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Efecto Mariposa","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":21,"lastName":"Benson","length":254.37995,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Por quererte","status":200,"ts":1543393393796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Dif Juz","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":22,"lastName":"Benson","length":219.16689,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"A Starting Point","status":200,"ts":1543393647796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":23,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"Downgrade","registration":1540907087796.0,"sessionId":887,"song":null,"status":200,"ts":1543393727796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":24,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"Home","registration":1540907087796.0,"sessionId":887,"song":null,"status":200,"ts":1543393733796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Jaci Velasquez","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":25,"lastName":"Benson","length":200.95955,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Something (Album Version)","status":200,"ts":1543393866796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"The Methadones","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":26,"lastName":"Benson","length":206.39302,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Falling Forward","status":200,"ts":1543394066796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"SKOLD vs. KMFDM","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":27,"lastName":"Benson","length":254.4322,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"It's Not What","status":200,"ts":1543394272796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Leatherface","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":28,"lastName":"Benson","length":221.09995,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Broken","status":200,"ts":1543394526796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Scooter","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":29,"lastName":"Benson","length":342.04689,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Suavemente","status":200,"ts":1543394747796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":30,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"Help","registration":1540907087796.0,"sessionId":887,"song":null,"status":200,"ts":1543394874796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Kat DeLuna featuring Busta Rhymes","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":31,"lastName":"Benson","length":213.13261,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Run The Show (featuring Busta Rhymes)","status":200,"ts":1543395089796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Boys Like Girls","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":32,"lastName":"Benson","length":232.22812,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Hero\/Heroine","status":200,"ts":1543395302796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":33,"lastName":"Benson","length":172.82567,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Monkey Man","status":200,"ts":1543395534796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Bebe And Cece Winans","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":34,"lastName":"Benson","length":281.59955,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"I.O.U. Me","status":200,"ts":1543395706796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":0,"lastName":"Martinez","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540646838796.0,"sessionId":140,"song":null,"status":200,"ts":1543395843796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Metric","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":1,"lastName":"Martinez","length":171.25832,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Gimme Sympathy","status":200,"ts":1543395917796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Coldplay","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":35,"lastName":"Benson","length":268.38159,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Yellow","status":200,"ts":1543395987796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Metallica","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":2,"lastName":"Martinez","length":505.52118,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Some Kind Of Monster","status":200,"ts":1543396088796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Ok Go","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":36,"lastName":"Benson","length":230.29506,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"There's A Fire","status":200,"ts":1543396255796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Die Mooskirchner","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":37,"lastName":"Benson","length":166.922,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Reisende Freunde","status":200,"ts":1543396485796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Method Man","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":3,"lastName":"Martinez","length":229.53751,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Say","status":200,"ts":1543396593796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Deadmau5","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":38,"lastName":"Benson","length":463.04608,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Slip","status":200,"ts":1543396651796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":39,"lastName":"Benson","length":null,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"GET","page":"Home","registration":1540907087796.0,"sessionId":887,"song":null,"status":200,"ts":1543396809796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"ZZ Top","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":4,"lastName":"Martinez","length":354.29832,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Tush","status":200,"ts":1543396822796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Stone Temple Pilots","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":310.25587,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":988,"song":"Dead & Bloated (LP Version)","status":200,"ts":1543396997796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Jazzamor","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":40,"lastName":"Benson","length":195.5522,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"cherish (the night_ the life_ the moon)","status":200,"ts":1543397114796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"The Cranberries","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":5,"lastName":"Martinez","length":141.50485,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Carry On","status":200,"ts":1543397176796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Joe Nichols","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":41,"lastName":"Benson","length":232.14975,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Brokenheartsville","status":200,"ts":1543397309796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Mutemath","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":6,"lastName":"Martinez","length":200.51546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Spotlight","status":200,"ts":1543397317796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Whiskeytown","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":7,"lastName":"Martinez","length":197.77261,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Mirror_ Mirror","status":200,"ts":1543397517796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Chingy","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":42,"lastName":"Benson","length":266.34404,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Gettin' It","status":200,"ts":1543397541796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":0,"lastName":"Duffy","length":null,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"GET","page":"Home","registration":1540146037796.0,"sessionId":921,"song":null,"status":200,"ts":1543397609796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Die Mooskirchner","auth":"Logged In","firstName":"Jayden","gender":"F","itemInSession":1,"lastName":"Duffy","length":169.29914,"level":"free","location":"Seattle-Tacoma-Bellevue, WA","method":"PUT","page":"NextSong","registration":1540146037796.0,"sessionId":921,"song":"Frisch und g'sund","status":200,"ts":1543397687796,"userAgent":"\"Mozilla\/5.0 (iPhone; CPU iPhone OS 7_1_2 like Mac OS X) AppleWebKit\/537.51.2 (KHTML, like Gecko) Version\/7.0 Mobile\/11D257 Safari\/9537.53\"","userId":"76"} {"artist":"Keith Sweat","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":8,"lastName":"Martinez","length":56.05832,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Telephone Love (LP Version)","status":200,"ts":1543397714796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Digitalism","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":9,"lastName":"Martinez","length":171.96363,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Moonlight","status":200,"ts":1543397770796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Fountains Of Wayne","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":43,"lastName":"Benson","length":197.40689,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Stacy's Mom","status":200,"ts":1543397807796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Simian Mobile Disco","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":10,"lastName":"Martinez","length":257.35791,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Clock","status":200,"ts":1543397941796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Useless I.D.","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":44,"lastName":"Benson","length":190.98077,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"State Of Fear","status":200,"ts":1543398004796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Ashanti","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":45,"lastName":"Benson","length":232.25424,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Foolish","status":200,"ts":1543398194796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Markus Kruneg\u00c3\u0083\u00c2\u00a5rd","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":11,"lastName":"Martinez","length":185.5473,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Genom tunna tyger","status":200,"ts":1543398198796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Billy Idol","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":12,"lastName":"Martinez","length":335.38567,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Rebel Yell (Acoustic Live on KROQ) (2001 Digital Remaster)","status":200,"ts":1543398383796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Abba","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":46,"lastName":"Benson","length":189.962,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Hasta Manana","status":200,"ts":1543398426796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Santogold","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":47,"lastName":"Benson","length":192.46975,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Lights Out","status":200,"ts":1543398615796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"John Mayer","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":13,"lastName":"Martinez","length":494.34077,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Come Back To Bed","status":200,"ts":1543398718796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Evergreen Terrace","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":48,"lastName":"Benson","length":155.92444,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Burned Alive By Time","status":200,"ts":1543398807796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":14,"lastName":"Martinez","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Settings","registration":1540646838796.0,"sessionId":140,"song":null,"status":200,"ts":1543398883796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Ladytron","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":49,"lastName":"Benson","length":215.11791,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Ghosts (Toxic Avenger Mix)","status":200,"ts":1543398962796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Feist","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":50,"lastName":"Benson","length":184.94649,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"My Moon My Man","status":200,"ts":1543399177796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Hollywood Undead","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":15,"lastName":"Martinez","length":196.41424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Young","status":200,"ts":1543399212796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Amorphis","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":51,"lastName":"Benson","length":299.07546,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":887,"song":"Towards And Against","status":200,"ts":1543399361796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Drowning Pool","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":16,"lastName":"Martinez","length":201.63873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Bodies","status":200,"ts":1543399408796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"I-Wayne","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":17,"lastName":"Martinez","length":213.86404,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Living In Love","status":200,"ts":1543399609796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":997,"song":null,"status":200,"ts":1543399718796,"userAgent":null,"userId":""} {"artist":"Portishead","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":18,"lastName":"Martinez","length":254.04036,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Sour Times","status":200,"ts":1543399822796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":19,"lastName":"Martinez","length":277.15873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1543400076796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":997,"song":null,"status":200,"ts":1543400239796,"userAgent":null,"userId":""} {"artist":"Angels and Airwaves","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":20,"lastName":"Martinez","length":302.05342,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"The Gift","status":200,"ts":1543400353796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"The Crests","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":21,"lastName":"Martinez","length":182.88281,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"16 Candles","status":200,"ts":1543400655796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":22,"lastName":"Martinez","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"Logout","registration":1540646838796.0,"sessionId":140,"song":null,"status":307,"ts":1543400656796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":23,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":140,"song":null,"status":200,"ts":1543400670796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":24,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":140,"song":null,"status":200,"ts":1543400741796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":25,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":140,"song":null,"status":307,"ts":1543400742796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":26,"lastName":"Martinez","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540646838796.0,"sessionId":140,"song":null,"status":200,"ts":1543400861796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Pet Shop Boys","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":27,"lastName":"Martinez","length":299.02322,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"It's A Sin (2001 Digital Remaster)","status":200,"ts":1543400873796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":28,"lastName":"Martinez","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Settings","registration":1540646838796.0,"sessionId":140,"song":null,"status":200,"ts":1543401398796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Paramore","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":29,"lastName":"Martinez","length":267.65016,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"The Only Exception (Album Version)","status":200,"ts":1543401585796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Carla Bruni","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":30,"lastName":"Martinez","length":153.20771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Promises Like Pie-Crust (Album)","status":200,"ts":1543401852796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Skillet","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":31,"lastName":"Martinez","length":232.46322,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Comatose (Comes Alive Version)","status":200,"ts":1543402005796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Concrete Blonde","auth":"Logged In","firstName":"Adler","gender":"M","itemInSession":0,"lastName":"Barrera","length":270.28853,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540835983796.0,"sessionId":942,"song":"Bloodletting (The Vampire Song)","status":200,"ts":1543402126796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"100"} {"artist":"Violeta Parra","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":32,"lastName":"Martinez","length":123.34975,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Parabienes Al Reves","status":200,"ts":1543402237796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Jonathan Coulton","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":33,"lastName":"Martinez","length":208.03873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Chiron Beta Prime","status":200,"ts":1543402360796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Nirvana","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":34,"lastName":"Martinez","length":219.08853,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Come As You Are","status":200,"ts":1543402568796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Metallica","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":35,"lastName":"Martinez","length":385.43628,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Broken_ Beat & Scarred","status":200,"ts":1543402787796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":252.70812,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":955,"song":"Someone To Save You","status":200,"ts":1543403092796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Bell Biv DeVoe","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":36,"lastName":"Martinez","length":262.00771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Poison","status":200,"ts":1543403172796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Kalle Baah","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":273.76281,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":955,"song":"Ugly Girls","status":200,"ts":1543403344796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Coldplay","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":37,"lastName":"Martinez","length":273.47546,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Trouble","status":200,"ts":1543403434796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Metric","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":38,"lastName":"Martinez","length":172.69506,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"The List","status":200,"ts":1543403707796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Everything But The Girl","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":39,"lastName":"Martinez","length":259.082,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Better Things","status":200,"ts":1543403879796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Calle 13","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":40,"lastName":"Martinez","length":290.84689,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Un Beso de Desayuno","status":200,"ts":1543404138796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":41,"lastName":"Martinez","length":214.67383,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"One Time","status":200,"ts":1543404428796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Ashanti","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":42,"lastName":"Martinez","length":232.25424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Foolish","status":200,"ts":1543404642796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"The Darkness","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":43,"lastName":"Martinez","length":217.05098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"I Believe In A Thing Called Love","status":200,"ts":1543404874796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Muse","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":44,"lastName":"Martinez","length":209.34485,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Supermassive Black Hole (Album Version)","status":200,"ts":1543405091796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Choeur Arm\u00c3\u0083\u00c2\u00a9nien de Sofia","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":45,"lastName":"Martinez","length":121.5473,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Le Corps de Notre Seigneur","status":200,"ts":1543405300796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Gyptian","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":46,"lastName":"Martinez","length":199.13098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Beautiful Lady","status":200,"ts":1543405421796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":47,"lastName":"Martinez","length":252.21179,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1543405620796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Jason Aldean","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":48,"lastName":"Martinez","length":305.52771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Hicktown","status":200,"ts":1543405872796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"The Rascals","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":49,"lastName":"Martinez","length":152.18893,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Love Is A Beautiful Thing (LP Version)","status":200,"ts":1543406177796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Keisha White","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":50,"lastName":"Martinez","length":251.42812,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Brother","status":200,"ts":1543406329796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Future Rock","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":51,"lastName":"Martinez","length":239.90812,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Gears","status":200,"ts":1543406580796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"The Power Station","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":52,"lastName":"Martinez","length":305.162,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Some Like It Hot","status":200,"ts":1543406819796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Sea Wolf","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":53,"lastName":"Martinez","length":225.802,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"Black Dirt (Album)","status":200,"ts":1543407124796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Rosana","auth":"Logged In","firstName":"Zachary","gender":"M","itemInSession":0,"lastName":"Thomas","length":250.33098,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540644861796.0,"sessionId":819,"song":"Pa Ti No Estoy","status":200,"ts":1543407201796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.7; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"19"} {"artist":"Jonny Lang","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":0,"lastName":"Harrell","length":246.04689,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Give Me Up Again","status":200,"ts":1543407267796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Enrique Iglesias","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":54,"lastName":"Martinez","length":217.99138,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":140,"song":"D\u00c3\u0083\u00c2\u00admelo","status":200,"ts":1543407349796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Eddie Vedder","auth":"Logged In","firstName":"Zachary","gender":"M","itemInSession":1,"lastName":"Thomas","length":236.30322,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540644861796.0,"sessionId":819,"song":"Society","status":200,"ts":1543407451796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.7; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"19"} {"artist":null,"auth":"Logged In","firstName":"Zachary","gender":"M","itemInSession":2,"lastName":"Thomas","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540644861796.0,"sessionId":819,"song":null,"status":200,"ts":1543407503796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.7; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"19"} {"artist":"Billy Bragg","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":1,"lastName":"Harrell","length":153.44281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"To Have And To Have Not","status":200,"ts":1543407513796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Zachary","gender":"M","itemInSession":3,"lastName":"Thomas","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"About","registration":1540644861796.0,"sessionId":819,"song":null,"status":200,"ts":1543407546796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.7; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"19"} {"artist":"Atreyu","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":2,"lastName":"Harrell","length":239.20281,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"This Flesh A Tomb (Album Version)","status":200,"ts":1543407666796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Race Car Riot","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":3,"lastName":"Harrell","length":257.30567,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"The Last In 4000","status":200,"ts":1543407905796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Home","registration":1541044398796.0,"sessionId":974,"song":null,"status":200,"ts":1543407973796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Sam Cooke","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":4,"lastName":"Harrell","length":122.04363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Ain't Misbehavin","status":200,"ts":1543408162796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Timbaland \/ Attitude \/ Keri Hilson","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":5,"lastName":"Harrell","length":274.85995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Hello","status":200,"ts":1543408284796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":6,"lastName":"Harrell","length":233.89995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Love Story","status":200,"ts":1543408558796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"TV On The Radio","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":7,"lastName":"Harrell","length":338.36363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Heroes","status":200,"ts":1543408791796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Jowell & Randy","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":8,"lastName":"Harrell","length":238.91546,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Velandote","status":200,"ts":1543409129796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Luiz Bonfa \/ Oscar Castro Neves \/ Lalo Schifrin","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":9,"lastName":"Harrell","length":202.29179,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Bossa Nova Cha Cha","status":200,"ts":1543409367796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Junior Vasquez","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":10,"lastName":"Harrell","length":406.12526,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Get Your Hands Off My Man (Nush Chocolate Factory Mix)","status":200,"ts":1543409569796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Peter Case","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":11,"lastName":"Harrell","length":272.24771,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Two Angels","status":200,"ts":1543409975796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Metric","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":12,"lastName":"Harrell","length":286.24934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Help I'm Alive","status":200,"ts":1543410247796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Eminem","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":13,"lastName":"Harrell","length":237.40036,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Medicine Ball","status":200,"ts":1543410533796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Zero 7","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":14,"lastName":"Harrell","length":380.26404,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"All Of Us","status":200,"ts":1543410770796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Akon","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":15,"lastName":"Harrell","length":260.8322,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Keep You Much Longer","status":200,"ts":1543411150796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Local Natives","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":16,"lastName":"Harrell","length":266.05669,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Wide Eyes","status":200,"ts":1543411410796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Erykah Badu","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":17,"lastName":"Harrell","length":286.9024,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Back In The Day","status":200,"ts":1543411676796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Magnet","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":18,"lastName":"Harrell","length":216.45016,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Where Happiness Lives","status":200,"ts":1543411962796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":19,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Downgrade","registration":1540472624796.0,"sessionId":944,"song":null,"status":200,"ts":1543411972796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":20,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":944,"song":null,"status":200,"ts":1543411982796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Escape The Fate","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":21,"lastName":"Harrell","length":217.28608,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Something","status":200,"ts":1543412178796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Modjo","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":22,"lastName":"Harrell","length":305.44934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Lady (Hear Me Tonight)","status":200,"ts":1543412395796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Ron Carter","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":23,"lastName":"Harrell","length":497.13587,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"I CAN'T GET STARTED","status":200,"ts":1543412700796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Four Day Hombre","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":24,"lastName":"Harrell","length":332.5122,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Inertia","status":200,"ts":1543413197796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Michael Franks","auth":"Logged In","firstName":"Katherine","gender":"F","itemInSession":0,"lastName":"Gay","length":282.01751,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540968306796.0,"sessionId":321,"song":"Rainy Night In Tokyo (Remastered LP Version)","status":200,"ts":1543413261796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_6_8) AppleWebKit\/534.59.10 (KHTML, like Gecko) Version\/5.1.9 Safari\/534.59.10\"","userId":"57"} {"artist":"Missy Elliott","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":25,"lastName":"Harrell","length":246.17751,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"The Rain [Supa Dupa Fly] (LP Version)","status":200,"ts":1543413529796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Hombres G","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":26,"lastName":"Harrell","length":296.30649,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Que soy yo para ti (Radio edit)","status":200,"ts":1543413775796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Flo Rida","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":27,"lastName":"Harrell","length":230.05995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Elevator [Feat. Timbaland] (Album Version)","status":200,"ts":1543414071796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Another Sunny Day","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":28,"lastName":"Harrell","length":173.21751,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Rio","status":200,"ts":1543414301796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":29,"lastName":"Harrell","length":null,"level":"paid","location":"Lansing-East Lansing, MI","method":"GET","page":"Home","registration":1540472624796.0,"sessionId":944,"song":null,"status":200,"ts":1543414330796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Sikth","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":30,"lastName":"Harrell","length":250.53995,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Peep Show","status":200,"ts":1543414474796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Home","registration":1541044398796.0,"sessionId":1019,"song":null,"status":200,"ts":1543414549796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"The Funky Lowlives","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":1,"lastName":"Simpson","length":280.34567,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":1019,"song":"Sail Into the Sun","status":200,"ts":1543414553796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":null,"auth":"Logged In","firstName":"Evelin","gender":"F","itemInSession":0,"lastName":"Ayala","length":null,"level":"free","location":"Milwaukee-Waukesha-West Allis, WI","method":"GET","page":"Home","registration":1541007976796.0,"sessionId":971,"song":null,"status":200,"ts":1543414573796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"34"} {"artist":"They Might Be Giants","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":31,"lastName":"Harrell","length":116.45342,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Particle Man (LP Version)","status":200,"ts":1543414724796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":2,"lastName":"Simpson","length":195.23873,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":1019,"song":"Cheryl Tweedy","status":200,"ts":1543414833796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Micachu","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":32,"lastName":"Harrell","length":52.74077,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Sweetheart","status":200,"ts":1543414840796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Light Of The World","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":33,"lastName":"Harrell","length":207.0722,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Midnight Groovin' (7\" Version) (2006 Digital Remaster)","status":200,"ts":1543414892796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Dan the Automator_ Del The Funky Homosapien_ Kid Koala","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":3,"lastName":"Simpson","length":246.69995,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":1019,"song":"Battle Song","status":200,"ts":1543415028796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"MC Hammer","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":34,"lastName":"Harrell","length":238.88934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Addams Groove","status":200,"ts":1543415099796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"La Polla Records","auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":4,"lastName":"Simpson","length":190.77179,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1541044398796.0,"sessionId":1019,"song":"Eutanasia","status":200,"ts":1543415274796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":35,"lastName":"Harrell","length":294.1122,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Fix You","status":200,"ts":1543415337796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Coldplay","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":36,"lastName":"Harrell","length":368.09098,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Fix You (Live)","status":200,"ts":1543415631796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1014,"song":null,"status":200,"ts":1543415701796,"userAgent":null,"userId":""} {"artist":"The Strokes","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":37,"lastName":"Harrell","length":196.28363,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Juicebox","status":200,"ts":1543415999796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":0,"lastName":"Larson","length":null,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Home","registration":1541045604796.0,"sessionId":875,"song":null,"status":200,"ts":1543416024796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"Fall Out Boy","auth":"Logged In","firstName":"Devin","gender":"M","itemInSession":1,"lastName":"Larson","length":180.40118,"level":"free","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1541045604796.0,"sessionId":875,"song":"Dance_ Dance","status":200,"ts":1543416119796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"60"} {"artist":"Bright Eyes","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":38,"lastName":"Harrell","length":224.80934,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"At The Bottom Of Everything","status":200,"ts":1543416195796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":39,"lastName":"Harrell","length":227.65669,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Irreplaceable","status":200,"ts":1543416419796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":"Big D and The Kids Table","auth":"Logged In","firstName":"Kate","gender":"F","itemInSession":40,"lastName":"Harrell","length":184.842,"level":"paid","location":"Lansing-East Lansing, MI","method":"PUT","page":"NextSong","registration":1540472624796.0,"sessionId":944,"song":"Shining On (feat. Scott Grella) (Grella's Techno Remix)","status":200,"ts":1543416646796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"97"} {"artist":null,"auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":0,"lastName":"Harris","length":null,"level":"free","location":"Eugene, OR","method":"GET","page":"Home","registration":1540906915796.0,"sessionId":941,"song":null,"status":200,"ts":1543417963796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Iron Maiden","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":1,"lastName":"Harris","length":409.5473,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":941,"song":"Ghost Of The Navigator","status":200,"ts":1543418037796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Nada Surf","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":298.44853,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":948,"song":"Comes A Time","status":200,"ts":1543418261796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Toto","auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":1,"lastName":"Owens","length":411.19302,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1541032432796.0,"sessionId":948,"song":"Home Of The Brave","status":200,"ts":1543418559796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"Relient K","auth":"Logged In","firstName":"Ayla","gender":"F","itemInSession":0,"lastName":"Johnson","length":240.92689,"level":"free","location":"Santa Rosa, CA","method":"PUT","page":"NextSong","registration":1540880381796.0,"sessionId":949,"song":"I So Hate Consequences (Album Version)","status":200,"ts":1543418831796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"63"} {"artist":"Silverchair","auth":"Logged In","firstName":"Kynnedi","gender":"F","itemInSession":0,"lastName":"Sanchez","length":242.96444,"level":"free","location":"Cedar Rapids, IA","method":"PUT","page":"NextSong","registration":1541079034796.0,"sessionId":927,"song":"The Greatest View (Album Version)","status":200,"ts":1543418894796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_8_5) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"89"} {"artist":"Morcheeba","auth":"Logged In","firstName":"Makinley","gender":"F","itemInSession":0,"lastName":"Jones","length":347.71546,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541091973796.0,"sessionId":881,"song":"The Sea","status":200,"ts":1543419088796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"17"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Kynnedi","gender":"F","itemInSession":1,"lastName":"Sanchez","length":195.94404,"level":"free","location":"Cedar Rapids, IA","method":"PUT","page":"NextSong","registration":1541079034796.0,"sessionId":927,"song":"Sincerit\u00c3\u0083\u00c2\u00a9 Et Jalousie","status":200,"ts":1543419136796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_8_5) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"89"} {"artist":"The Notorious B.I.G.","auth":"Logged In","firstName":"Makinley","gender":"F","itemInSession":1,"lastName":"Jones","length":223.73832,"level":"free","location":"Chicago-Naperville-Elgin, IL-IN-WI","method":"PUT","page":"NextSong","registration":1541091973796.0,"sessionId":881,"song":"Unbelievable (Amended Version)","status":200,"ts":1543419435796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"17"} {"artist":null,"auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":0,"lastName":"Finley","length":null,"level":"free","location":"Richmond, VA","method":"GET","page":"Home","registration":1541013292796.0,"sessionId":810,"song":null,"status":200,"ts":1543420590796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":"No Doubt \/ Bounty Killer","auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":1,"lastName":"Finley","length":206.65424,"level":"free","location":"Richmond, VA","method":"PUT","page":"NextSong","registration":1541013292796.0,"sessionId":810,"song":"Hey Baby","status":200,"ts":1543420593796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":911,"song":null,"status":200,"ts":1543420724796,"userAgent":null,"userId":""} {"artist":"Cut Copy","auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":2,"lastName":"Finley","length":299.44118,"level":"free","location":"Richmond, VA","method":"PUT","page":"NextSong","registration":1541013292796.0,"sessionId":810,"song":"Lights & Music","status":200,"ts":1543420799796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":1002,"song":null,"status":200,"ts":1543420804796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":211.01669,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":1002,"song":"Tighten Up","status":200,"ts":1543420856796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Eagles","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":0,"lastName":"Levine","length":181.86404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"Earlybird (LP Version)","status":200,"ts":1543420997796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Derek Webb","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":0,"lastName":"Lynch","length":166.19057,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":963,"song":"Please_ Before I Go","status":200,"ts":1543421003796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Agony Scene","auth":"Logged In","firstName":"Cierra","gender":"F","itemInSession":3,"lastName":"Finley","length":175.85587,"level":"free","location":"Richmond, VA","method":"PUT","page":"NextSong","registration":1541013292796.0,"sessionId":810,"song":"Screams Turn To Silence (Album Version)","status":200,"ts":1543421098796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"96"} {"artist":"Moving Mountains","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":1,"lastName":"Lynch","length":513.07057,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":963,"song":"8105","status":200,"ts":1543421169796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Switchblade Symphony","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":1,"lastName":"Levine","length":248.34567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"Dollhouse","status":200,"ts":1543421178796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Mr Sam ft. Kirsty Hawkshaw","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":487.99302,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"Insight","status":200,"ts":1543421426796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Temper Trap","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":2,"lastName":"Lynch","length":192.67873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":963,"song":"Fader","status":200,"ts":1543421682796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1023,"song":null,"status":200,"ts":1543421822796,"userAgent":null,"userId":""} {"artist":"The B-52's","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":3,"lastName":"Lynch","length":321.54077,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":963,"song":"Love Shack","status":200,"ts":1543421874796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Angus & Julia Stone","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":262.42567,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"Jewels And Gold","status":200,"ts":1543421913796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Harmonia","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":655.77751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"Sehr kosmisch","status":200,"ts":1543422175796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Spinal Tap","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":4,"lastName":"Lynch","length":135.78404,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":963,"song":"Jazz Oddyssey III","status":200,"ts":1543422195796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Peter Sellers","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Hicks","length":142.39302,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":1000,"song":"She Loves You","status":200,"ts":1543422300796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Kings Of Convenience","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":5,"lastName":"Lynch","length":188.44689,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":963,"song":"Me In You","status":200,"ts":1543422330796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Hellhammer","auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":1,"lastName":"Hicks","length":241.71057,"level":"free","location":"Salinas, CA","method":"PUT","page":"NextSong","registration":1540008898796.0,"sessionId":1000,"song":"Maniac","status":200,"ts":1543422442796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"37"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":6,"lastName":"Lynch","length":236.09424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":963,"song":"Canada","status":200,"ts":1543422518796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Elbow","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":7,"lastName":"Lynch","length":221.85751,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":963,"song":"Grounds For Divorce","status":200,"ts":1543422754796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Kreator","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":0,"lastName":"Benson","length":294.53016,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":1013,"song":"Riot Of Violence","status":200,"ts":1543422764796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1023,"song":null,"status":200,"ts":1543422776796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":1023,"song":null,"status":307,"ts":1543422777796,"userAgent":null,"userId":""} {"artist":"Slightly Stoopid","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":145.76281,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"Anti Socialistic","status":200,"ts":1543422830796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Pavement","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":8,"lastName":"Lynch","length":149.83791,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":963,"song":"Heaven Is A Truck","status":200,"ts":1543422975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Ryan Bingham","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":123.11465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"Boracho Station","status":200,"ts":1543422975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":9,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Settings","registration":1540223723796.0,"sessionId":963,"song":null,"status":200,"ts":1543423016796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"The Swell Season","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":1,"lastName":"Benson","length":201.82159,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":1013,"song":"Paper Cup","status":200,"ts":1543423058796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Shakira","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":192.70485,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"Did it Again","status":200,"ts":1543423098796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"PJ Harvey","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":10,"lastName":"Lynch","length":227.5522,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":963,"song":"This Is Love","status":200,"ts":1543423124796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Gibonni","auth":"Logged In","firstName":"Emily","gender":"F","itemInSession":2,"lastName":"Benson","length":379.68934,"level":"paid","location":"Augusta-Richmond County, GA-SC","method":"PUT","page":"NextSong","registration":1540907087796.0,"sessionId":1013,"song":"OVO MI JE `KOLA","status":200,"ts":1543423259796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"58"} {"artist":"Lifehouse","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":181.26322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"From Where You Are","status":200,"ts":1543423290796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Joe Vasconcellos","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":11,"lastName":"Lynch","length":262.5824,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":963,"song":"Las seis","status":200,"ts":1543423351796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Juanes","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":266.50077,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"Tu Y Yo","status":200,"ts":1543423471796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Rage Against The Machine","auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":12,"lastName":"Lynch","length":338.46812,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540223723796.0,"sessionId":963,"song":"The Ghost Of Tom Joad","status":200,"ts":1543423613796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":1004,"song":null,"status":200,"ts":1543423718796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Extremoduro","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":281.3122,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"Cerca del suelo","status":200,"ts":1543423737796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Eric Church","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Harris","length":229.56363,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":929,"song":"How 'Bout You","status":200,"ts":1543423862796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":1032,"song":null,"status":200,"ts":1543423874796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"The Decemberists","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":248.55465,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":1032,"song":"Billy Liar","status":200,"ts":1543423894796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":null,"auth":"Logged In","firstName":"Jacqueline","gender":"F","itemInSession":13,"lastName":"Lynch","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Downgrade","registration":1540223723796.0,"sessionId":963,"song":null,"status":200,"ts":1543423965796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"29"} {"artist":"Coldplay","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":237.45261,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"42","status":200,"ts":1543424018796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Talkdemonic","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Harris","length":129.85424,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":929,"song":"Mountaintops In Caves","status":200,"ts":1543424091796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Gary Allan","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":2,"lastName":"Harris","length":244.34893,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":929,"song":"Best I Ever Had","status":200,"ts":1543424220796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Buju Banton","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":247.19628,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"My Woman Now","status":200,"ts":1543424255796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Thirteen Senses","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":218.5922,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"Into The Fire","status":200,"ts":1543424502796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":1023,"song":null,"status":200,"ts":1543424545796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"B.o.B","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":269.63546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1004,"song":"Nothin' On You [feat. Bruno Mars] (Album Version)","status":200,"ts":1543424720796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Angels Of Light & Akron\/Family","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":150.33424,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":991,"song":"Awake","status":200,"ts":1543424793796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":1004,"song":null,"status":200,"ts":1543425207796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"Logout","registration":1540794356796.0,"sessionId":1004,"song":null,"status":307,"ts":1543425208796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":18,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1004,"song":null,"status":200,"ts":1543426240796,"userAgent":null,"userId":""} {"artist":"Daddy Yankee","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":218.20036,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1023,"song":"Que Tengo Que Hacer","status":200,"ts":1543426351796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Simian Mobile Disco","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":198.53016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1023,"song":"I Believe","status":200,"ts":1543426569796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Arctic Monkeys","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":193.43628,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1023,"song":"From The Ritz To The Rubble","status":200,"ts":1543426767796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":1023,"song":null,"status":200,"ts":1543426928796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Plain White T's","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":232.202,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1023,"song":"Hey There Delilah","status":200,"ts":1543426960796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Dead Weather","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":216.92036,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1023,"song":"Hang You From The Heavens","status":200,"ts":1543427192796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":1023,"song":null,"status":200,"ts":1543427535796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":984,"song":null,"status":307,"ts":1543429490796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":1,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":984,"song":null,"status":200,"ts":1543429491796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Temple Of The Dog","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":2,"lastName":"Griffin","length":243.9571,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Hunger Strike","status":200,"ts":1543429643796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Port O'Brien","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":0,"lastName":"Rodriguez","length":339.06893,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":999,"song":"Close The Lid","status":200,"ts":1543429719796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"E.s.t.","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":3,"lastName":"Griffin","length":103.65342,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Ajar","status":200,"ts":1543429886796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Discovery","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":4,"lastName":"Griffin","length":153.83465,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"It\u0019s Not My Fault (It\u0019s My Fault)","status":200,"ts":1543429989796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":999,"song":null,"status":200,"ts":1543430113796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Jack's Mannequin","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":5,"lastName":"Griffin","length":251.92444,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Dark Blue (Album Version)","status":200,"ts":1543430142796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Fisher","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":133.98159,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":999,"song":"Rianna","status":200,"ts":1543430217796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":3,"lastName":"Rodriguez","length":200.202,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":999,"song":"Wild World","status":200,"ts":1543430350796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Musiq \/ Ayana","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":6,"lastName":"Griffin","length":286.37995,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Girl Next Door","status":200,"ts":1543430393796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Zee Avi","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":4,"lastName":"Rodriguez","length":162.61179,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":999,"song":"Darling","status":200,"ts":1543430550796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"McGuinn_ Clark & Hillman","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":7,"lastName":"Griffin","length":256.9922,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Little Mama","status":200,"ts":1543430679796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Band Of Horses","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":5,"lastName":"Rodriguez","length":321.14893,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":999,"song":"The Funeral (Album Version)","status":200,"ts":1543430712796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Dead Kennedys","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":8,"lastName":"Griffin","length":216.842,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Halloween","status":200,"ts":1543430935796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Deftones","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":6,"lastName":"Rodriguez","length":268.01587,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":999,"song":"Rx Queen (LP Version)","status":200,"ts":1543431033796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Eric Clapton","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":9,"lastName":"Griffin","length":279.95383,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Smile","status":200,"ts":1543431151796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Katy Perry","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":7,"lastName":"Rodriguez","length":179.40853,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":999,"song":"I Kissed A Girl","status":200,"ts":1543431301796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Bebo Norman","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":10,"lastName":"Griffin","length":178.65098,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Perhaps She'll Wait","status":200,"ts":1543431430796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":8,"lastName":"Rodriguez","length":227.05587,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":999,"song":"Listen (LP Version)","status":200,"ts":1543431480796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":9,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"Logout","registration":1540511766796.0,"sessionId":999,"song":null,"status":307,"ts":1543431481796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":10,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":999,"song":null,"status":200,"ts":1543431555796,"userAgent":null,"userId":""} {"artist":"Four Tet","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":11,"lastName":"Griffin","length":101.69424,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Harmony One","status":200,"ts":1543431608796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"THERION","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":12,"lastName":"Griffin","length":293.45914,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"The Khlysti Evangelist","status":200,"ts":1543431709796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":11,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Help","registration":null,"sessionId":999,"song":null,"status":200,"ts":1543431720796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":12,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Help","registration":null,"sessionId":999,"song":null,"status":200,"ts":1543431727796,"userAgent":null,"userId":""} {"artist":"Shakira","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":13,"lastName":"Griffin","length":232.25424,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Donde Estas Corazon","status":200,"ts":1543432002796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Luke Bryan","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":14,"lastName":"Griffin","length":242.36363,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"All My Friends Say","status":200,"ts":1543432234796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Miike Snow","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":15,"lastName":"Griffin","length":263.88853,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Animal","status":200,"ts":1543432476796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Iyaz","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":16,"lastName":"Griffin","length":181.9424,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Replay","status":200,"ts":1543432739796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Slightly Stoopid","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":17,"lastName":"Griffin","length":243.46077,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Officer","status":200,"ts":1543432920796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Pulp","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":18,"lastName":"Griffin","length":270.75873,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Mile End","status":200,"ts":1543433163796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Sting","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":19,"lastName":"Griffin","length":360.85506,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"When We Dance","status":200,"ts":1543433433796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1042,"song":null,"status":200,"ts":1543433659796,"userAgent":null,"userId":""} {"artist":"Portishead","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":20,"lastName":"Griffin","length":347.76771,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Threads","status":200,"ts":1543433793796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Cliff Richard & The Shadows","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":21,"lastName":"Griffin","length":130.45506,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Nine Times Out Of Ten (1998 Digital Remaster)","status":200,"ts":1543434140796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":22,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Downgrade","registration":1541057188796.0,"sessionId":984,"song":null,"status":200,"ts":1543434279796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Regina Spektor","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":23,"lastName":"Griffin","length":188.36853,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Ghost Of Corporate Future [Live in California 2006]","status":200,"ts":1543434279796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Built To Spill","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":24,"lastName":"Griffin","length":390.26893,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Good Ol' Boredom","status":200,"ts":1543434467796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Esperanza Spalding","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":25,"lastName":"Griffin","length":306.83383,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Loro","status":200,"ts":1543434857796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Trey Songz","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":223.97342,"level":"free","location":"London, KY","method":"PUT","page":"NextSong","registration":1540613280796.0,"sessionId":908,"song":"Brand New","status":200,"ts":1543435163796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"13"} {"artist":"Justin Timberlake","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":26,"lastName":"Griffin","length":267.25832,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Rock Your Body","status":200,"ts":1543435163796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":233.69098,"level":"free","location":"London, KY","method":"PUT","page":"NextSong","registration":1540613280796.0,"sessionId":908,"song":"Invalid","status":200,"ts":1543435386796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.102 Safari\/537.36\"","userId":"13"} {"artist":"Shinedown","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":27,"lastName":"Griffin","length":200.07138,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Cry For Help (Album Version)","status":200,"ts":1543435430796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Annuals","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":28,"lastName":"Griffin","length":348.15955,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Complete_ Or Completing","status":200,"ts":1543435630796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Joshua Radin","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":29,"lastName":"Griffin","length":160.44363,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Everything'll Be Alright (Will's Lullaby)","status":200,"ts":1543435978796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Il Divo","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":30,"lastName":"Griffin","length":227.42159,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"The Winner Takes It All (Va Todo Al Ganador)","status":200,"ts":1543436138796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Jesse Cook","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":31,"lastName":"Griffin","length":214.83057,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Olodum","status":200,"ts":1543436365796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":0,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"GET","page":"Home","registration":1540558108796.0,"sessionId":954,"song":null,"status":200,"ts":1543436495796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":1,"lastName":"Klein","length":194.55955,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Dirty Little Secret","status":200,"ts":1543436552796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Edward Sharpe & The Magnetic Zeros","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":32,"lastName":"Griffin","length":306.31138,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Home","status":200,"ts":1543436579796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Rhapsody","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":2,"lastName":"Klein","length":555.91138,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"The Mighty Ride Of The Firelord","status":200,"ts":1543436746796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Hollywood Undead","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":33,"lastName":"Griffin","length":161.25342,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Pain","status":200,"ts":1543436885796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Helloween","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":34,"lastName":"Griffin","length":345.36444,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Back Against The Wall","status":200,"ts":1543437046796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Rosi Golan","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":3,"lastName":"Klein","length":189.3873,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Think of Me","status":200,"ts":1543437301796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Usher Featuring Kelis","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":35,"lastName":"Griffin","length":269.40036,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"U Don't Have To Call","status":200,"ts":1543437391796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":1036,"song":null,"status":200,"ts":1543437422796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Timbaland \/ Justin Timberlake \/ Nelly Furtado","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":235.2322,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":1036,"song":"Give It To Me","status":200,"ts":1543437487796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Eminem \/ Dr. Dre \/ 50 Cent","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":4,"lastName":"Klein","length":297.482,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Crack A Bottle","status":200,"ts":1543437490796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Bryan Adams","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":36,"lastName":"Griffin","length":201.1424,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Don't Ya Say It","status":200,"ts":1543437660796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Madonna","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":2,"lastName":"Burns","length":220.29016,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":1036,"song":"Revolver [feat. Lil Wayne]","status":200,"ts":1543437722796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"The Roots","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":5,"lastName":"Klein","length":393.29914,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Grits","status":200,"ts":1543437787796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Nirvana","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":37,"lastName":"Griffin","length":186.48771,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Breed","status":200,"ts":1543437861796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Gino Vannelli","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":38,"lastName":"Griffin","length":198.73914,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"People Gotta Move","status":200,"ts":1543438047796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Roots \/ Wadud Ahmad","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":6,"lastName":"Klein","length":170.70975,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Take It There","status":200,"ts":1543438180796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Coldplay","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":39,"lastName":"Griffin","length":298.762,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Shiver","status":200,"ts":1543438245796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"LCD Soundsystem","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":7,"lastName":"Klein","length":298.89261,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Tribulations","status":200,"ts":1543438350796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Cartel","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":40,"lastName":"Griffin","length":223.79057,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Luckie Street","status":200,"ts":1543438543796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Carter Burwell","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":8,"lastName":"Klein","length":138.70975,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Bella's Lullaby (Twilight Soundtrack Version)","status":200,"ts":1543438648796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Coral","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":41,"lastName":"Griffin","length":237.63546,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Fireflies","status":200,"ts":1543438766796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Misfits","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":9,"lastName":"Klein","length":112.06485,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Rat Fink","status":200,"ts":1543438786796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":10,"lastName":"Klein","length":215.40526,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Inaudible Melodies","status":200,"ts":1543438898796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"R\u00c3\u0083\u00c2\u00b6yksopp","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":42,"lastName":"Griffin","length":210.99057,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"In Space","status":200,"ts":1543439003796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Sounds from the Ground","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":11,"lastName":"Klein","length":458.31791,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Where The Wild Things Were","status":200,"ts":1543439113796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Mantronix","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":43,"lastName":"Griffin","length":353.64526,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Ladies (Dub) (2005 Digital Remaster)","status":200,"ts":1543439213796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Death Cab for Cutie","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":44,"lastName":"Griffin","length":189.3873,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"I Will Follow You into the Dark (Album Version)","status":200,"ts":1543439566796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Green Day","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":12,"lastName":"Klein","length":256.02567,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Last Night On Earth [feat. Green Day & The Cast Of American Idiot] (Album Version)","status":200,"ts":1543439571796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Scooter","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":45,"lastName":"Griffin","length":347.19302,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Across The Sky","status":200,"ts":1543439755796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":46,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Downgrade","registration":1541057188796.0,"sessionId":984,"song":null,"status":200,"ts":1543439790796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bodo Wartke","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":377.41669,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1039,"song":"Ich trau' mich nicht","status":200,"ts":1543439809796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Chris Classic","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":13,"lastName":"Klein","length":180.61016,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Witch Doctor","status":200,"ts":1543439827796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Creedence Clearwater Revival","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":14,"lastName":"Klein","length":135.52281,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Travelin' Band","status":200,"ts":1543440007796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"LMFAO \/ Lil Jon","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":47,"lastName":"Griffin","length":222.17098,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Shots","status":200,"ts":1543440102796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Alison Moyet","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":15,"lastName":"Klein","length":230.00771,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Love Resurrection","status":200,"ts":1543440142796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Amos Lee","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":160.49587,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1039,"song":"Colors","status":200,"ts":1543440186796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Los Dynamite","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":48,"lastName":"Griffin","length":253.1522,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Smile","status":200,"ts":1543440324796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Alter Ego","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":16,"lastName":"Klein","length":285.09995,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Rocker","status":200,"ts":1543440372796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Colossal","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":49,"lastName":"Griffin","length":206.99383,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Brave The Elements","status":200,"ts":1543440577796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Alice In Chains","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":17,"lastName":"Klein","length":423.6273,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Over Now","status":200,"ts":1543440657796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Interpol","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":50,"lastName":"Griffin","length":299.72853,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Rest My Chemistry","status":200,"ts":1543440783796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":18,"lastName":"Klein","length":185.46893,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Cover Me","status":200,"ts":1543441080796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Death In Vegas","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":51,"lastName":"Griffin","length":270.23628,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Girls","status":200,"ts":1543441082796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Harmonia","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":19,"lastName":"Klein","length":655.77751,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Sehr kosmisch","status":200,"ts":1543441265796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"George Thorogood And The Destroyers","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":52,"lastName":"Griffin","length":238.34077,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Alley Oop (Live)","status":200,"ts":1543441352796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":53,"lastName":"Griffin","length":337.97179,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"A Beautiful Mess (Album Version)","status":200,"ts":1543441590796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Los Campesinos","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":20,"lastName":"Klein","length":138.10893,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"We throw parties_ you throw knives","status":200,"ts":1543441920796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Insane Clown Posse","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":54,"lastName":"Griffin","length":98.66404,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"I Stab People","status":200,"ts":1543441927796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Joaquin Sabina","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":55,"lastName":"Griffin","length":223.86893,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Besos Con Sal","status":200,"ts":1543442025796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":21,"lastName":"Klein","length":229.0673,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"One Less Lonely Girl","status":200,"ts":1543442058796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Green Day","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":56,"lastName":"Griffin","length":527.09832,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"King For A Day\/Shout (Live)","status":200,"ts":1543442248796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Saliva","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":22,"lastName":"Klein","length":208.40444,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Doperide","status":200,"ts":1543442287796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"John Mayer","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":23,"lastName":"Klein","length":267.38893,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Why Georgia","status":200,"ts":1543442495796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Frightened Rabbit","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":24,"lastName":"Klein","length":214.93506,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Set You Free","status":200,"ts":1543442762796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Righteous Brothers","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":57,"lastName":"Griffin","length":215.90159,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Unchained Melody","status":200,"ts":1543442775796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Umek vs Ramirez","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":25,"lastName":"Klein","length":362.29179,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Hablando","status":200,"ts":1543442976796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Tinchy Stryder \/ Taio Cruz","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":58,"lastName":"Griffin","length":195.36934,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Take Me Back","status":200,"ts":1543442990796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"PeterLicht","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":59,"lastName":"Griffin","length":306.80771,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Heiterkeit","status":200,"ts":1543443185796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Lanae' Hale","auth":"Logged In","firstName":"Walter","gender":"M","itemInSession":0,"lastName":"Frye","length":195.36934,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540919166796.0,"sessionId":451,"song":"Beautiful Things","status":200,"ts":1543443199796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"39"} {"artist":"Eagles","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":26,"lastName":"Klein","length":346.25261,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Frail Grasp On The Big Picture","status":200,"ts":1543443338796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Primus","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":60,"lastName":"Griffin","length":382.98077,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Over The Electric Grapevine","status":200,"ts":1543443491796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Cake","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":27,"lastName":"Klein","length":164.25751,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Never There","status":200,"ts":1543443684796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Zero 7","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":28,"lastName":"Klein","length":346.38322,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Milton At Midnight","status":200,"ts":1543443848796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Faithless","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":61,"lastName":"Griffin","length":218.04363,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Drifting Away","status":200,"ts":1543443873796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Saxon","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":62,"lastName":"Griffin","length":217.15546,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Redline (2009 Digital Remaster)","status":200,"ts":1543444091796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Elvis Costello & The Attractions","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":29,"lastName":"Klein","length":168.64608,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Moods For Moderns","status":200,"ts":1543444194796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":63,"lastName":"Griffin","length":277.83791,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Everyone's At It","status":200,"ts":1543444308796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":30,"lastName":"Klein","length":239.3073,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"You're The One","status":200,"ts":1543444362796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Keyshia Cole","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":64,"lastName":"Griffin","length":244.00934,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Work It Out","status":200,"ts":1543444585796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"James","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":31,"lastName":"Klein","length":219.89832,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"She's A Star","status":200,"ts":1543444601796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Queen","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":32,"lastName":"Klein","length":139.17995,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Who Wants To Live Forever (With Commentary)","status":200,"ts":1543444820796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Boz Scaggs","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":65,"lastName":"Griffin","length":319.03302,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Look What You've Done To Me","status":200,"ts":1543444829796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Sia","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":33,"lastName":"Klein","length":208.61342,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Playground","status":200,"ts":1543444959796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Max Richter","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":66,"lastName":"Griffin","length":173.40036,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Arboretum","status":200,"ts":1543445148796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"10cc","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":34,"lastName":"Klein","length":300.40771,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Hotel","status":200,"ts":1543445167796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Silverstein","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":67,"lastName":"Griffin","length":193.90649,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Smile In Your Sleep (Album Version)","status":200,"ts":1543445321796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":68,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":984,"song":null,"status":200,"ts":1543445365796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Combat 84","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":35,"lastName":"Klein","length":121.0771,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Barry Prudom (Re-Mix)","status":200,"ts":1543445467796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Sanctus Real","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":69,"lastName":"Griffin","length":257.2273,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Lay Down My Guns","status":200,"ts":1543445514796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Pink Martini_Ari Shapiro","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":36,"lastName":"Klein","length":180.1922,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"But Now I'm Black","status":200,"ts":1543445588796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":37,"lastName":"Klein","length":239.3073,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"You're The One","status":200,"ts":1543445768796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Jay-Z","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":70,"lastName":"Griffin","length":288.31302,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Ride Or Die","status":200,"ts":1543445771796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Handsome Family","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":38,"lastName":"Klein","length":287.65995,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"The Woman Downstairs","status":200,"ts":1543446007796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Hellogoodbye","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":71,"lastName":"Griffin","length":176.56118,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"All Of Your Love","status":200,"ts":1543446059796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Janet Jackson","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":72,"lastName":"Griffin","length":260.88444,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Because Of Love","status":200,"ts":1543446235796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Gorillaz","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":39,"lastName":"Klein","length":227.05587,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Plastic Beach (Feat. Mick Jones and Paul Simonon)","status":200,"ts":1543446294796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Silverstein","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":73,"lastName":"Griffin","length":222.79791,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Smashed Into Pieces (Album Version)","status":200,"ts":1543446495796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Example","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":40,"lastName":"Klein","length":180.4273,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Kickstarts","status":200,"ts":1543446521796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Shania Twain","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":41,"lastName":"Klein","length":198.32118,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"In My Car (I'll Be The Driver)","status":200,"ts":1543446701796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Skindred","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":74,"lastName":"Griffin","length":238.602,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Ease Up","status":200,"ts":1543446717796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":75,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":984,"song":null,"status":200,"ts":1543446858796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Kanye West","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":42,"lastName":"Klein","length":196.77995,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Jesus Walks","status":200,"ts":1543446899796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Aloe Blacc","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":76,"lastName":"Griffin","length":244.1922,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"I Need A Dollar","status":200,"ts":1543446955796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Common","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":43,"lastName":"Klein","length":224.13016,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"GO!","status":200,"ts":1543447095796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"The Belle Stars","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":77,"lastName":"Griffin","length":178.85995,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Iko Iko","status":200,"ts":1543447199796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Feist","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":44,"lastName":"Klein","length":223.7122,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Mushaboom","status":200,"ts":1543447319796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Lupe Fiasco","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":78,"lastName":"Griffin","length":312.92036,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"The Coolest (Explicit Album Version)","status":200,"ts":1543447377796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Natalie Cole","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":45,"lastName":"Klein","length":188.57751,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Stairway To The Stars","status":200,"ts":1543447542796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Placebo","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":79,"lastName":"Griffin","length":190.61506,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"The Bitter End","status":200,"ts":1543447689796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"2Mex","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":46,"lastName":"Klein","length":243.06893,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Making Money Off God feat. Bus Driver","status":200,"ts":1543447730796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Brother Ali","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":80,"lastName":"Griffin","length":204.53832,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"The Puzzle","status":200,"ts":1543447879796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Meat Loaf","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":47,"lastName":"Klein","length":597.86404,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Paradise By The Dashboard Light","status":200,"ts":1543447973796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"MC Lars","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":81,"lastName":"Griffin","length":222.87628,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"It's Not Easy (Being Green) (Featuring Pierre Bouvier Of Simple Plan)","status":200,"ts":1543448083796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":82,"lastName":"Griffin","length":236.35546,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Ego","status":200,"ts":1543448305796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Joy Division","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":83,"lastName":"Griffin","length":254.09261,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Transmission","status":200,"ts":1543448541796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Dierks Bentley","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":48,"lastName":"Klein","length":239.12444,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"I Wanna Make You Close Your Eyes","status":200,"ts":1543448570796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1043,"song":null,"status":200,"ts":1543448703796,"userAgent":null,"userId":""} {"artist":"Devendra Banhart","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":84,"lastName":"Griffin","length":134.76526,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"At The Hop","status":200,"ts":1543448795796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Camera Obscura","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":49,"lastName":"Klein","length":207.01995,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"If Looks Could Kill","status":200,"ts":1543448809796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Prodigy","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":85,"lastName":"Griffin","length":335.90812,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Breathe","status":200,"ts":1543448929796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Aventura","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":50,"lastName":"Klein","length":278.04689,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Peligro","status":200,"ts":1543449016796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Die Sekte","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":86,"lastName":"Griffin","length":206.18404,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Mittelfinga ab feat. Sido_ MOK_ B-Tight_ Bendt","status":200,"ts":1543449264796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Kid Dynamite","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":51,"lastName":"Klein","length":119.95383,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Never Met The Gooch","status":200,"ts":1543449294796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Eminem \/ Bizarre","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":52,"lastName":"Klein","length":244.55791,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Amityville","status":200,"ts":1543449413796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Explosions In The Sky","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":87,"lastName":"Griffin","length":220.3424,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"So Long_ Lonesome","status":200,"ts":1543449470796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"}
467.616628
604
0.697639
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Sydney Youngblood","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":53,"lastName":"Klein","length":238.07955,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"Ain't No Sunshine","status":200,"ts":1543449657796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Gang Starr","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":88,"lastName":"Griffin","length":151.92771,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"My Advice 2 You (Explicit)","status":200,"ts":1543449690796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"3OH!3","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":89,"lastName":"Griffin","length":192.522,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"My First Kiss (Feat. Ke$ha) [Album Version]","status":200,"ts":1543449841796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"R\u00c3\u0083\u00c2\u00b6yksopp","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":54,"lastName":"Klein","length":369.81506,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"The Girl and The Robot","status":200,"ts":1543449895796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Kajagoogoo","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":90,"lastName":"Griffin","length":223.55546,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Too Shy","status":200,"ts":1543450033796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Jimmy Castor Bunch","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":91,"lastName":"Griffin","length":306.54649,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Potential","status":200,"ts":1543450256796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Ministry","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":55,"lastName":"Klein","length":186.69669,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"The Great Satan (What Would Satan Do Mix)","status":200,"ts":1543450264796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Bouncing Souls","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":56,"lastName":"Klein","length":117.31546,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":954,"song":"The Screamer","status":200,"ts":1543450450796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Tegan And Sara","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":92,"lastName":"Griffin","length":129.67138,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Knife Going In (Album Version)","status":200,"ts":1543450562796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Silverchair","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":93,"lastName":"Griffin","length":242.96444,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"The Greatest View (Album Version)","status":200,"ts":1543450691796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Enigma","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":94,"lastName":"Griffin","length":242.78159,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"T.N.T. For The Brain (112 Bpm) (Radio Edit)","status":200,"ts":1543450933796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Anis","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":95,"lastName":"Griffin","length":278.12526,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Mon M\u00c3\u0083\u00c2\u00a9tro","status":200,"ts":1543451175796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Seal","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":96,"lastName":"Griffin","length":254.06649,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Fly Like An Eagle","status":200,"ts":1543451453796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"UNKLE Feat. Josh Homme","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":97,"lastName":"Griffin","length":307.19955,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Restless","status":200,"ts":1543451707796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":98,"lastName":"Griffin","length":239.3073,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"You're The One","status":200,"ts":1543452014796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Elastica","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":99,"lastName":"Griffin","length":141.92281,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Blue","status":200,"ts":1543452253796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Capone-N-Noreaga","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":100,"lastName":"Griffin","length":194.82077,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Channel 10","status":200,"ts":1543452394796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Morris Day","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":101,"lastName":"Griffin","length":442.46159,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"The Oak Tree (Album Version)","status":200,"ts":1543452588796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":102,"lastName":"Griffin","length":302.91546,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"What If I Do?","status":200,"ts":1543453030796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Olive","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":103,"lastName":"Griffin","length":264.12363,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"You're Not Alone","status":200,"ts":1543453332796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Olle Adolphson","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":104,"lastName":"Griffin","length":202.39628,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"En Glad Calypso Om V\u00c3\u0083\u00c2\u00a5ren (Live '62)","status":200,"ts":1543453596796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Streetlight Manifesto","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":303.33342,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":1011,"song":"Down_ Down_ Down To Mehphisto's Cafe (Album Version)","status":200,"ts":1543453763796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Frank Reyes","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":105,"lastName":"Griffin","length":239.67302,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Tu Eres Ajena","status":200,"ts":1543453798796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Andres Calamaro","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":106,"lastName":"Griffin","length":217.5473,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Estadio Azteca","status":200,"ts":1543454037796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Zero 7","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":107,"lastName":"Griffin","length":279.562,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Sleeper","status":200,"ts":1543454254796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Mark Ronson featuring Tiggers","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":108,"lastName":"Griffin","length":245.18485,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Toxic","status":200,"ts":1543454533796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Keith Sweat","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":109,"lastName":"Griffin","length":295.78404,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Merry Go Round (Remastered Single Version)","status":200,"ts":1543454778796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Wakey!Wakey!","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":110,"lastName":"Griffin","length":145.03138,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Square Peg Round Hole","status":200,"ts":1543455073796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Mercury Program","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":111,"lastName":"Griffin","length":292.362,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Eqypt","status":200,"ts":1543455218796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Kid Cudi \/ Kanye West \/ Common","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":112,"lastName":"Griffin","length":237.76608,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Make Her Say","status":200,"ts":1543455510796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Nekromantix","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":113,"lastName":"Griffin","length":263.10485,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Nice Day For A Resurrection","status":200,"ts":1543455747796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":114,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":984,"song":null,"status":200,"ts":1543455764796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"J. Karjalainen & Mustat Lasit","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":115,"lastName":"Griffin","length":336.74404,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Sinisten t\u00c3\u0083\u00c2\u00a4htien alla","status":200,"ts":1543456010796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Matt Wertz","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":116,"lastName":"Griffin","length":171.17995,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"Wade Through The Night","status":200,"ts":1543456346796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Insane Clown Posse","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":117,"lastName":"Griffin","length":233.82159,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":984,"song":"My Axe","status":200,"ts":1543456517796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Thin Lizzy","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":0,"lastName":"Cook","length":214.59546,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":951,"song":"It's Only Money","status":200,"ts":1543458271796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Crystal Castles","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":1,"lastName":"Cook","length":186.38322,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":951,"song":"Untrust us","status":200,"ts":1543458485796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"The Prodigy","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":2,"lastName":"Cook","length":302.602,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":951,"song":"Full Throttle","status":200,"ts":1543458671796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Kid Cudi \/ Kanye West \/ Common","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":3,"lastName":"Cook","length":237.76608,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":951,"song":"Make Her Say","status":200,"ts":1543458973796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"Kim Carnes","auth":"Logged In","firstName":"Kaleb","gender":"M","itemInSession":4,"lastName":"Cook","length":217.28608,"level":"free","location":"Yuba City, CA","method":"PUT","page":"NextSong","registration":1540679673796.0,"sessionId":951,"song":"Crazy In The Night (Barking At Airplanes)","status":200,"ts":1543459210796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"54"} {"artist":"The Velvet Underground","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":165.95546,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":1045,"song":"White Light\/White Heat","status":200,"ts":1543460277796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Katie Melua","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":218.09587,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":1045,"song":"I Cried For You","status":200,"ts":1543460442796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Cedell Davis","auth":"Logged In","firstName":"Alivia","gender":"F","itemInSession":0,"lastName":"Terrell","length":178.36363,"level":"free","location":"Parkersburg-Vienna, WV","method":"PUT","page":"NextSong","registration":1540505391796.0,"sessionId":587,"song":"Chicken Hawk","status":200,"ts":1543460835796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"4"} {"artist":null,"auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540306145796.0,"sessionId":990,"song":null,"status":200,"ts":1543465425796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Frou Frou","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Smith","length":277.34159,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":990,"song":"Breathe In","status":200,"ts":1543465636796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Justin Timberlake","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":2,"lastName":"Smith","length":313.0771,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":990,"song":"What Goes Around...Comes Around","status":200,"ts":1543465913796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":"Michael Bubl\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Harris","length":253.88363,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":1038,"song":"Moondance (Album Version)","status":200,"ts":1543467355796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Bill Withers","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":1,"lastName":"Harris","length":383.73832,"level":"free","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1541097374796.0,"sessionId":1038,"song":"Make Love To Your Mind","status":200,"ts":1543467608796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"14"} {"artist":"Cut Copy","auth":"Logged In","firstName":"Jordyn","gender":"F","itemInSession":0,"lastName":"Powell","length":267.54567,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1540828399796.0,"sessionId":865,"song":"Feel The Love","status":200,"ts":1543479522796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"98"} {"artist":"School Of Seven Bells","auth":"Logged In","firstName":"Jordyn","gender":"F","itemInSession":1,"lastName":"Powell","length":176.97914,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1540828399796.0,"sessionId":865,"song":"s.Ada.Licht","status":200,"ts":1543479789796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"98"} {"artist":null,"auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1540621059796.0,"sessionId":1053,"song":null,"status":200,"ts":1543483675796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Rick Ross \/ T-Pain","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":225.69751,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":1016,"song":"The Boss","status":200,"ts":1543489167796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Keri Hilson \/ Lil Wayne","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":247.77098,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":1016,"song":"Turnin Me On","status":200,"ts":1543489392796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Cute Is What We Aim For","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Roth","length":222.22322,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":931,"song":"Risque (Album Version)","status":200,"ts":1543489411796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":"Los Aut\u00c3\u0083\u00c2\u00a9nticos Decadentes","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Fox","length":218.48771,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":1016,"song":"La Guitarra","status":200,"ts":1543489639796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"June Carter Cash;Johnny Cash","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Fox","length":180.21832,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":1016,"song":"If I Were A Carpenter","status":200,"ts":1543489857796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"I Set My Friends On Fire","auth":"Logged In","firstName":"Sylvie","gender":"F","itemInSession":0,"lastName":"Cruz","length":206.39302,"level":"free","location":"Washington-Arlington-Alexandria, DC-VA-MD-WV","method":"PUT","page":"NextSong","registration":1540266185796.0,"sessionId":1005,"song":"But The NUNS Are Watching","status":200,"ts":1543494067796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"10"} {"artist":"King Cobb Steelie","auth":"Logged In","firstName":"Theodore","gender":"M","itemInSession":0,"lastName":"Smith","length":373.7073,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540306145796.0,"sessionId":1055,"song":"Starvo","status":200,"ts":1543497251796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"52"} {"artist":null,"auth":"Logged In","firstName":"Celeste","gender":"F","itemInSession":0,"lastName":"Williams","length":null,"level":"free","location":"Klamath Falls, OR","method":"GET","page":"Home","registration":1541077528796.0,"sessionId":947,"song":null,"status":200,"ts":1543499081796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.103 Safari\/537.36\"","userId":"53"} {"artist":null,"auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540492941796.0,"sessionId":1001,"song":null,"status":200,"ts":1543499104796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"David Bowie","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":174.41914,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Sorrow (1997 Digital Remaster)","status":200,"ts":1543499907796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1040,"song":null,"status":200,"ts":1543499974796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Help","registration":null,"sessionId":1040,"song":null,"status":200,"ts":1543499981796,"userAgent":null,"userId":""} {"artist":"J Dilla","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":232.46322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Won't Do","status":200,"ts":1543500081796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Hot Hot Heat","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":295.02649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"In Cairo","status":200,"ts":1543500313796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Norther","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":236.85179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"We Rock","status":200,"ts":1543500608796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Postal Service","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":226.61179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Nothing Better (Album)","status":200,"ts":1543500844796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"311","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":264.56771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Something Out Of Nothing","status":200,"ts":1543501070796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jonas Brothers","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":249.67791,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"When You Look Me In The Eyes","status":200,"ts":1543501334796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Platero Y Tu","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":368.29995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Cantalojas","status":200,"ts":1543501583796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Martina McBride","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":193.802,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"In My Daughter's Eyes","status":200,"ts":1543501951796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ben Folds Five","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":292.23138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Smoke","status":200,"ts":1543502144796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Seine","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":173.66159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"So far so long","status":200,"ts":1543502436796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Shinedown","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":258.97751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"What A Shame (Album Version)","status":200,"ts":1543502609796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Iva","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":205.322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Vanity Case (nouvelle version)","status":200,"ts":1543502867796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cathy Davey","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":273.52771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Hammerhead (Explicit)","status":200,"ts":1543503072796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jorge Reyes Valencia","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":127.81669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Hekura","status":200,"ts":1543503345796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sonic Youth","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":299.10159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Candle","status":200,"ts":1543503472796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":983,"song":null,"status":307,"ts":1543503713796,"userAgent":null,"userId":""} {"artist":"John Mayer","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":241.99791,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Slow Dancing In A Burning Room","status":200,"ts":1543503771796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":1,"lastName":"George","length":null,"level":"paid","location":"Birmingham-Hoover, AL","method":"GET","page":"Home","registration":1541020249796.0,"sessionId":983,"song":null,"status":200,"ts":1543503847796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":2,"lastName":"George","length":235.49342,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Geek In The Pink (Album Version)","status":200,"ts":1543503949796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":17,"lastName":"Cuevas","length":283.19302,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Technologic","status":200,"ts":1543504012796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Flyleaf","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":3,"lastName":"George","length":184.89424,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Again","status":200,"ts":1543504184796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":1046,"song":null,"status":200,"ts":1543504254796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Flight Of The Conchords","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":0,"lastName":"Burns","length":206.8371,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":1058,"song":"Carol Brown","status":200,"ts":1543504268796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":18,"lastName":"Cuevas","length":233.69098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Invalid","status":200,"ts":1543504295796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Aesop Rock","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":266.16118,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1046,"song":"Daylight","status":200,"ts":1543504307796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Two Door Cinema Club","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":4,"lastName":"George","length":168.09751,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Undercover Martyn","status":200,"ts":1543504368796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Leftover Crack","auth":"Logged In","firstName":"Lily","gender":"F","itemInSession":1,"lastName":"Burns","length":254.98077,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1540621059796.0,"sessionId":1058,"song":"Clear Channel (Fuck Off!)","status":200,"ts":1543504474796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"32"} {"artist":"Tiny Vipers","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":19,"lastName":"Cuevas","length":210.23302,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"They Might Follow You","status":200,"ts":1543504528796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Miley Cyrus","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":5,"lastName":"George","length":236.85179,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"The Climb","status":200,"ts":1543504536796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Foolish Things","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":266.86649,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1046,"song":"Who Can Compare","status":200,"ts":1543504573796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":20,"lastName":"Cuevas","length":220.89098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Somebody To Love","status":200,"ts":1543504738796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jarabe De Palo","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":6,"lastName":"George","length":283.14077,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Tiempo","status":200,"ts":1543504772796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"James","gender":"M","itemInSession":0,"lastName":"Martin","length":238.8371,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540810448796.0,"sessionId":761,"song":"Happy Alone","status":200,"ts":1543504830796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 9.0; Windows NT 6.1; Trident\/5.0)","userId":"79"} {"artist":"Clarence Carter","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":3,"lastName":"Smith","length":161.4624,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1046,"song":"I Smell A Rat (LP Version)","status":200,"ts":1543504839796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":4,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"Logout","registration":1541016707796.0,"sessionId":1046,"song":null,"status":307,"ts":1543504840796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Purple Ribbon All-Stars feat. Big Boi","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":21,"lastName":"Cuevas","length":242.83383,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Kryptonite (Radio Edit) (feat. Big Boi)","status":200,"ts":1543504958796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Hannah Montana","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":7,"lastName":"George","length":202.03057,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Old Blue Jeans","status":200,"ts":1543505055796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":5,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1046,"song":null,"status":200,"ts":1543505089796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":6,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":1046,"song":null,"status":307,"ts":1543505090796,"userAgent":null,"userId":""} {"artist":"Iyaz","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":22,"lastName":"Cuevas","length":181.9424,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Replay","status":200,"ts":1543505200796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":7,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":1046,"song":null,"status":200,"ts":1543505200796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Plastilina Mosh","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":8,"lastName":"Smith","length":236.56444,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1046,"song":"Aquamosh","status":200,"ts":1543505221796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Common","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":8,"lastName":"George","length":144.16934,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Be (Intro)","status":200,"ts":1543505257796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Chris Brown","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":23,"lastName":"Cuevas","length":275.1473,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"I May Never Find","status":200,"ts":1543505381796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"iio","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":9,"lastName":"George","length":217.80853,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Runaway (Original)","status":200,"ts":1543505401796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Eric B. & Rakim","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":9,"lastName":"Smith","length":224.23465,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1046,"song":"Eric B. Is On The Cut","status":200,"ts":1543505457796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Carla Thomas","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":10,"lastName":"George","length":174.62812,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"A Woman's Love (LP Version)","status":200,"ts":1543505618796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Five Finger Death Punch","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":24,"lastName":"Cuevas","length":180.32281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Falling in Hate","status":200,"ts":1543505656796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sting","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":11,"lastName":"George","length":285.93587,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Desert Rose","status":200,"ts":1543505792796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Chiodos","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":25,"lastName":"Cuevas","length":143.20281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"If I Cut My Hair_ Hawaii Will Sink (Album Version)","status":200,"ts":1543505836796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dion & The Belmonts","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":26,"lastName":"Cuevas","length":138.65751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"I Wonder Why","status":200,"ts":1543505979796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"T.I.","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":12,"lastName":"George","length":261.98159,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Prayin For Help (Amended Album Version)","status":200,"ts":1543506077796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":27,"lastName":"Cuevas","length":224.49587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Sinister Kid","status":200,"ts":1543506117796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bon Iver","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":13,"lastName":"George","length":218.98404,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Flume","status":200,"ts":1543506338796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":28,"lastName":"Cuevas","length":237.97506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"All The Right Moves","status":200,"ts":1543506341796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cameo","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":14,"lastName":"George","length":263.52281,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Word Up","status":200,"ts":1543506556796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Mos Def \/ Slick Rick","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":29,"lastName":"Cuevas","length":274.442,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Auditorium","status":200,"ts":1543506578796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"HAMMERFALL","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":15,"lastName":"George","length":236.01587,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Hallowed Be My Name","status":200,"ts":1543506819796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Plies","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":30,"lastName":"Cuevas","length":223.65995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"I Am The Club (Explicit Album Version)","status":200,"ts":1543506852796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Slaid Cleaves","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":16,"lastName":"George","length":198.76526,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Hearts Break","status":200,"ts":1543507055796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Todd Barry","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":31,"lastName":"Cuevas","length":126.82404,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Sugar Ray (LP Version)","status":200,"ts":1543507075796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":32,"lastName":"Cuevas","length":245.36771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"The Way I Loved You","status":200,"ts":1543507201796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Minnie Riperton","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":17,"lastName":"George","length":287.79057,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Inside My Love","status":200,"ts":1543507253796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Flying Lotus","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":33,"lastName":"Cuevas","length":181.52444,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Comet Course","status":200,"ts":1543507446796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Muse","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":18,"lastName":"George","length":211.12118,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Can't Take My Eyes Off You","status":200,"ts":1543507540796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Edenbridge","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":34,"lastName":"Cuevas","length":137.69098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Elsewhere","status":200,"ts":1543507627796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Frank Ifield","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":19,"lastName":"George","length":138.23955,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Hong Kong Blues","status":200,"ts":1543507751796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":35,"lastName":"Cuevas","length":239.3073,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"You're The One","status":200,"ts":1543507764796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jay-Z","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":20,"lastName":"George","length":245.68118,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Threat","status":200,"ts":1543507889796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Angels and Airwaves","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":36,"lastName":"Cuevas","length":302.05342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"The Gift","status":200,"ts":1543508003796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Stone Sour","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":21,"lastName":"George","length":236.77342,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Idle Hands (Album Version)","status":200,"ts":1543508134796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":37,"lastName":"Cuevas","length":239.3073,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"You're The One","status":200,"ts":1543508305796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Airborne Toxic Event","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":22,"lastName":"George","length":237.13914,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Wishing Well","status":200,"ts":1543508370796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"3 Doors Down","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":38,"lastName":"Cuevas","length":237.13914,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Here Without You","status":200,"ts":1543508544796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Hazmat Modine","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":23,"lastName":"George","length":285.02159,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Dry Spell","status":200,"ts":1543508607796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":39,"lastName":"Cuevas","length":224.67873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Secrets","status":200,"ts":1543508781796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Liz Phair","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":24,"lastName":"George","length":187.34975,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Fuck and Run","status":200,"ts":1543508892796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Nickelback","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":40,"lastName":"Cuevas","length":238.18404,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Far Away (Album Version)","status":200,"ts":1543509005796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Massive Attack","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":25,"lastName":"George","length":326.60853,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Girl I Love You","status":200,"ts":1543509079796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Madonna","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":41,"lastName":"Cuevas","length":266.89261,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Beat Goes On [Featuring Kanye West] (Album Version)","status":200,"ts":1543509243796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sick Puppies","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":26,"lastName":"George","length":227.83955,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Don't Walk Away","status":200,"ts":1543509405796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Pixies","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":42,"lastName":"Cuevas","length":184.2673,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Bone Machine","status":200,"ts":1543509509796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Andres Calamaro","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":27,"lastName":"George","length":65.88036,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Mi Marfil","status":200,"ts":1543509632796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Aesop Rock","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":43,"lastName":"Cuevas","length":245.65506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"None Shall Pass (Main)","status":200,"ts":1543509693796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Subways","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":28,"lastName":"George","length":182.17751,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"With You","status":200,"ts":1543509697796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Enya","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":29,"lastName":"George","length":179.90485,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"To Go Beyond (II)","status":200,"ts":1543509879796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"P!nk","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":44,"lastName":"Cuevas","length":227.02975,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Glitter In The Air","status":200,"ts":1543509938796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":0,"lastName":"Martinez","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540646838796.0,"sessionId":1017,"song":null,"status":200,"ts":1543510028796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Jos\u00c3\u0083\u00c2\u00a9 Gonzalez","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":30,"lastName":"George","length":158.48444,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Heartbeats","status":200,"ts":1543510058796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Passion","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":1,"lastName":"Martinez","length":405.10649,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Better Is One Day (Stereo Trax)","status":200,"ts":1543510062796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"The Cat Empire","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":45,"lastName":"Cuevas","length":316.65587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Two Shoes","status":200,"ts":1543510165796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Mariah Carey","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":31,"lastName":"George","length":246.09914,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Someday","status":200,"ts":1543510216796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Restiform Bodies","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":32,"lastName":"George","length":229.14567,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Interactive Halloween Bear","status":200,"ts":1543510462796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Alice Deejay","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":2,"lastName":"Martinez","length":216.5024,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Better Off Alone","status":200,"ts":1543510467796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Interpol","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":46,"lastName":"Cuevas","length":200.202,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Next Evil","status":200,"ts":1543510481796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Usher featuring will.i.am","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":395.72853,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":1003,"song":"OMG","status":200,"ts":1543510514796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Lupe Fiasco feat. Matthew Santos","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":47,"lastName":"Cuevas","length":213.34159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Fighters (feat. Matthew Santos) (Amended Album Version)","status":200,"ts":1543510681796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Los Aut\u00c3\u0083\u00c2\u00a9nticos Decadentes","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":3,"lastName":"Martinez","length":218.48771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"La Guitarra","status":200,"ts":1543510683796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Brand New Disaster","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":33,"lastName":"George","length":190.82404,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"At Least It's Raining","status":200,"ts":1543510691796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Shinedown","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":34,"lastName":"George","length":229.43302,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Breaking Inside (Album Version)","status":200,"ts":1543510881796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Cocorosie","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":48,"lastName":"Cuevas","length":232.17587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"The Moon Asked The Crow","status":200,"ts":1543510894796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Legi\u00c3\u0083\u00c2\u00a3o Urbana","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":4,"lastName":"Martinez","length":307.3824,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Pais E Filhos","status":200,"ts":1543510901796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Cameo","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":1,"lastName":"Kirby","length":211.98322,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":1003,"song":"Word Up!","status":200,"ts":1543510909796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":2,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"About","registration":1541022995796.0,"sessionId":1003,"song":null,"status":200,"ts":1543510931796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":null,"auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":3,"lastName":"Kirby","length":null,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"GET","page":"Home","registration":1541022995796.0,"sessionId":1003,"song":null,"status":200,"ts":1543510957796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Atmosphere","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":35,"lastName":"George","length":244.61016,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Dreamer","status":200,"ts":1543511110796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Matthew Good","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":4,"lastName":"Kirby","length":319.16363,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":1003,"song":"Born Losers","status":200,"ts":1543511120796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"The Avett Brothers","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":49,"lastName":"Cuevas","length":227.99628,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"January Wedding","status":200,"ts":1543511126796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"James Newton Howard","auth":"Logged In","firstName":"Alivia","gender":"F","itemInSession":0,"lastName":"Terrell","length":141.5571,"level":"free","location":"Parkersburg-Vienna, WV","method":"PUT","page":"NextSong","registration":1540505391796.0,"sessionId":1054,"song":"I'm Sorry","status":200,"ts":1543511176796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"4"} {"artist":"Lily Allen","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":5,"lastName":"Martinez","length":206.65424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"The Fear","status":200,"ts":1543511208796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":50,"lastName":"Cuevas","length":201.79546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Revelry","status":200,"ts":1543511353796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eric B. & Rakim","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":36,"lastName":"George","length":281.86077,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"I Know You Got Soul","status":200,"ts":1543511354796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Eminem","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":6,"lastName":"Martinez","length":248.2673,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Hello","status":200,"ts":1543511414796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"David Gray","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":51,"lastName":"Cuevas","length":217.33832,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Stella The Artist","status":200,"ts":1543511554796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sade","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":37,"lastName":"George","length":278.46485,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"The Sweetest Taboo","status":200,"ts":1543511635796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9 feat. Jay-Z","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":7,"lastName":"Martinez","length":219.19302,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"That's How You Like It","status":200,"ts":1543511662796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Kato","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":52,"lastName":"Cuevas","length":195.47383,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Hey Shorty (Yeah Yeah Pt. II) (Feat. U$O & Johnson)","status":200,"ts":1543511771796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Wise Intelligent","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":8,"lastName":"Martinez","length":300.56444,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"I'll Never Kill Again","status":200,"ts":1543511881796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"El Arrebato","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":38,"lastName":"George","length":234.57914,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Quiero Quererte Querer","status":200,"ts":1543511913796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Strokes","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":53,"lastName":"Cuevas","length":155.34975,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Is This It","status":200,"ts":1543511966796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"50 Cent","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":54,"lastName":"Cuevas","length":223.89506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"I Get Money","status":200,"ts":1543512121796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dorsey Burnette","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":39,"lastName":"George","length":125.85751,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"(There Was A) Tall Oak Tree","status":200,"ts":1543512147796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"America","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":9,"lastName":"Martinez","length":262.89587,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Horse With No Name","status":200,"ts":1543512181796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Mesa (Portuguese Group)","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":40,"lastName":"George","length":246.33424,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"V\u00c3\u0083\u00c2\u00adcio De Ti","status":200,"ts":1543512272796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Alaska Y Dinarama","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":55,"lastName":"Cuevas","length":231.44444,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Solo Creo Lo Que Veo","status":200,"ts":1543512344796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Rammstein","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":10,"lastName":"Martinez","length":244.40118,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Sehnsucht","status":200,"ts":1543512443796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Damien Rice","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":41,"lastName":"George","length":284.29016,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Woman Like A Man","status":200,"ts":1543512518796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Vittorio Lue","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":11,"lastName":"Martinez","length":33.802,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Sequencer Mood 1","status":200,"ts":1543512687796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Scissor Sisters","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":12,"lastName":"Martinez","length":209.34485,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Ooh","status":200,"ts":1543512720796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"The Coffee Club Orchestra","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":42,"lastName":"George","length":386.76853,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Overture","status":200,"ts":1543512802796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Eagle-Eye Cherry","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":13,"lastName":"Martinez","length":242.78159,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Save Tonight","status":200,"ts":1543512929796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":56,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":1041,"song":null,"status":200,"ts":1543512951796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Curtis Mayfield","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":14,"lastName":"Martinez","length":534.33424,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Move On Up (Extended LP Version)","status":200,"ts":1543513171796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Russian Circles","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":43,"lastName":"George","length":346.20036,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Death Rides a Horse","status":200,"ts":1543513188796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":15,"lastName":"Martinez","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Downgrade","registration":1540646838796.0,"sessionId":1017,"song":null,"status":200,"ts":1543513243796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":16,"lastName":"Martinez","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540646838796.0,"sessionId":1017,"song":null,"status":200,"ts":1543513249796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Casiotone For The Painfully Alone","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":0,"lastName":"Gutierrez","length":139.41506,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":721,"song":"Old Panda Days (w\/ Nick Krgovich)","status":200,"ts":1543513262796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Ron Carter","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":57,"lastName":"Cuevas","length":497.13587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"I CAN'T GET STARTED","status":200,"ts":1543513314796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":1,"lastName":"Gutierrez","length":null,"level":"free","location":"Columbia, SC","method":"GET","page":"Home","registration":1540809335796.0,"sessionId":721,"song":null,"status":200,"ts":1543513332796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Metallica","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":2,"lastName":"Gutierrez","length":386.66404,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":721,"song":"No Remorse","status":200,"ts":1543513401796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Captain Sensible","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":44,"lastName":"George","length":338.72934,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Wot","status":200,"ts":1543513534796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Renato Carosone","auth":"Logged In","firstName":"Walter","gender":"M","itemInSession":0,"lastName":"Frye","length":192.57424,"level":"free","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540919166796.0,"sessionId":1047,"song":"Blues (2005 Digital Remaster)","status":200,"ts":1543513551796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"39"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":17,"lastName":"Martinez","length":233.69098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Invalid","status":200,"ts":1543513705796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Escape The Fate","auth":"Logged In","firstName":"Joseph","gender":"M","itemInSession":3,"lastName":"Gutierrez","length":259.39546,"level":"free","location":"Columbia, SC","method":"PUT","page":"NextSong","registration":1540809335796.0,"sessionId":721,"song":"Harder Than You Know","status":200,"ts":1543513787796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.75.14 (KHTML, like Gecko) Version\/7.0.3 Safari\/537.75.14\"","userId":"75"} {"artist":"Yael Na\u00c3\u0083\u00c2\u00afm","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":58,"lastName":"Cuevas","length":214.85669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"New Soul","status":200,"ts":1543513811796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Radiohead","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":45,"lastName":"George","length":317.93587,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Weird Fishes\/Arpeggi","status":200,"ts":1543513872796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Death Cab for Cutie","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":18,"lastName":"Martinez","length":216.42404,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"A Lack Of Color (Album Version)","status":200,"ts":1543513938796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"New Order","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":59,"lastName":"Cuevas","length":313.62567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Sooner Than You Think","status":200,"ts":1543514025796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":19,"lastName":"Martinez","length":239.3073,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"You're The One","status":200,"ts":1543514154796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Fukkk Offf","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":46,"lastName":"George","length":409.05098,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Love My Shake","status":200,"ts":1543514189796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":47,"lastName":"George","length":null,"level":"paid","location":"Birmingham-Hoover, AL","method":"GET","page":"Home","registration":1541020249796.0,"sessionId":983,"song":null,"status":200,"ts":1543514278796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Slipknot","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":60,"lastName":"Cuevas","length":159.76444,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Spit It Out [Explicit]","status":200,"ts":1543514338796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Slaves To Gravity","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":20,"lastName":"Martinez","length":225.25342,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Big Red","status":200,"ts":1543514393796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":61,"lastName":"Cuevas","length":242.99057,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Holy Roller Novocaine","status":200,"ts":1543514497796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":48,"lastName":"George","length":277.15873,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1543514598796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Amos Lee","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":21,"lastName":"Martinez","length":259.26485,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"All My Friends","status":200,"ts":1543514618796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Duncan Dhu","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":62,"lastName":"Cuevas","length":202.91873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"No Puedo Evitar (Pensar En Ti)","status":200,"ts":1543514739796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Reel Big Fish","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":49,"lastName":"George","length":185.80853,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"She Has A Girlfriend Now","status":200,"ts":1543514875796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Amon Amarth","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":22,"lastName":"Martinez","length":298.55302,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Burning Creation","status":200,"ts":1543514877796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"John Mayer","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":63,"lastName":"Cuevas","length":241.6322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Back To You","status":200,"ts":1543514941796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The 69 Eyes","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":50,"lastName":"George","length":224.78322,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Don't Turn Your Back On Fear","status":200,"ts":1543515060796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Ladytron","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":23,"lastName":"Martinez","length":278.07302,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Ladybird","status":200,"ts":1543515175796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Leonard Cohen","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":64,"lastName":"Cuevas","length":307.43465,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Famous Blue Raincoat","status":200,"ts":1543515182796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bright Eyes","auth":"Logged In","firstName":"Aleena","gender":"F","itemInSession":0,"lastName":"Kirby","length":200.72444,"level":"paid","location":"Waterloo-Cedar Falls, IA","method":"PUT","page":"NextSong","registration":1541022995796.0,"sessionId":1069,"song":"Take It Easy (love Nothing) (Album Version)","status":200,"ts":1543515225796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"44"} {"artist":"Gym Class Heroes","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":51,"lastName":"George","length":428.77342,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Live Forever [Fly With Me] [feat. Daryl Hall]","status":200,"ts":1543515284796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Beverley Craven","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":24,"lastName":"Martinez","length":219.34975,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Promise Me","status":200,"ts":1543515453796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Masta Killa","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":65,"lastName":"Cuevas","length":195.70893,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Ringing Bells","status":200,"ts":1543515489796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Andre Hazes","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":25,"lastName":"Martinez","length":206.70649,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Droomland (duet met Paul de Leeuw)","status":200,"ts":1543515672796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":26,"lastName":"Martinez","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"Logout","registration":1540646838796.0,"sessionId":1017,"song":null,"status":307,"ts":1543515673796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Beirut","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":66,"lastName":"Cuevas","length":185.15546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"My Night With the Prostitute From Marseille","status":200,"ts":1543515684796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Tyrone Wells","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":52,"lastName":"George","length":275.80036,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"This Is Beautiful","status":200,"ts":1543515712796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":27,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1017,"song":null,"status":200,"ts":1543515736796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":67,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":1041,"song":null,"status":200,"ts":1543515737796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":28,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":1017,"song":null,"status":307,"ts":1543515737796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":29,"lastName":"Martinez","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540646838796.0,"sessionId":1017,"song":null,"status":200,"ts":1543515768796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Melanie","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":68,"lastName":"Cuevas","length":245.86404,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Look What They Done To My Song_ Ma","status":200,"ts":1543515869796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jimmy Eat World","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":30,"lastName":"Martinez","length":166.00771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"The Middle","status":200,"ts":1543515878796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Blackstreet","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":53,"lastName":"George","length":26.90567,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Taja's Lude (Interlude)","status":200,"ts":1543515987796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Omara Portuondo","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":54,"lastName":"George","length":202.86649,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Juramento","status":200,"ts":1543516013796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":31,"lastName":"Martinez","length":146.25914,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"The News","status":200,"ts":1543516044796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Melody Gardot","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":69,"lastName":"Cuevas","length":245.83791,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Love Me Like A River Does","status":200,"ts":1543516114796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Charttraxx Karaoke","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":32,"lastName":"Martinez","length":225.17506,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Fireflies","status":200,"ts":1543516190796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Grant Lee Buffalo","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":55,"lastName":"George","length":169.76934,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Mighty Joe Moon","status":200,"ts":1543516215796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Radiohead","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":56,"lastName":"George","length":261.45914,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Karma Police","status":200,"ts":1543516384796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Madeleine Peyroux","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":33,"lastName":"Martinez","length":258.71628,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Love And Treachery","status":200,"ts":1543516415796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Bon Jovi","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":57,"lastName":"George","length":224.522,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"It's My Life","status":200,"ts":1543516645796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":70,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Downgrade","registration":1540940782796.0,"sessionId":1041,"song":null,"status":200,"ts":1543516649796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"James Taylor","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":34,"lastName":"Martinez","length":338.80771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Country Road","status":200,"ts":1543516673796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Jesse Cook","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":58,"lastName":"George","length":301.71383,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Canci\u00c3\u0083\u00c2\u00b3n Triste","status":200,"ts":1543516869796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Black Keys","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":35,"lastName":"Martinez","length":239.59465,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Unknown Brother","status":200,"ts":1543517011796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Radiohead","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":59,"lastName":"George","length":284.44689,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Kid A","status":200,"ts":1543517170796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Randy Crawford","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":36,"lastName":"Martinez","length":270.75873,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Almaz","status":200,"ts":1543517250796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Randy Crawford","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":60,"lastName":"George","length":270.75873,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Almaz","status":200,"ts":1543517454796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Dr. Alban","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":37,"lastName":"Martinez","length":210.05016,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Born In Africa","status":200,"ts":1543517520796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Two Door Cinema Club","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":61,"lastName":"George","length":189.67465,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"What You Know","status":200,"ts":1543517724796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Avett Brothers","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":38,"lastName":"Martinez","length":287.97342,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Head Full Of Doubt\/Road Full Of Promise","status":200,"ts":1543517730796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"The Bravery","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":62,"lastName":"George","length":187.37587,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Hot Pursuit","status":200,"ts":1543517913796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Greg Dulli","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":39,"lastName":"Martinez","length":221.17832,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Pussywillow","status":200,"ts":1543518017796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":63,"lastName":"George","length":284.05506,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Don't Cry (Original)","status":200,"ts":1543518100796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Major Organ And The Adding Machine","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":40,"lastName":"Martinez","length":46.05342,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Kissing Behind The Rubbery Grinder","status":200,"ts":1543518238796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"RJD2","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":41,"lastName":"Martinez","length":237.53098,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Beyond The Beyond (Instrumental)","status":200,"ts":1543518284796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Fatback","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":64,"lastName":"George","length":315.66322,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Yum Yum (Gimme Some)","status":200,"ts":1543518384796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":65,"lastName":"George","length":null,"level":"paid","location":"Birmingham-Hoover, AL","method":"GET","page":"Downgrade","registration":1541020249796.0,"sessionId":983,"song":null,"status":200,"ts":1543518387796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Secos And Molhados","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":42,"lastName":"Martinez","length":66.16771,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Caixinha De M\u00c3\u0083\u00c2\u00basica Do Jo\u00c3\u0083\u00c2\u00a3o","status":200,"ts":1543518521796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Marc Almond","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":43,"lastName":"Martinez","length":197.17179,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Mr. Sad","status":200,"ts":1543518587796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"The Tallest Man On Earth","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":66,"lastName":"George","length":197.40689,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"A Lion's Heart","status":200,"ts":1543518699796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Pavement","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":44,"lastName":"Martinez","length":149.83791,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Heaven Is A Truck","status":200,"ts":1543518784796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Kanye West","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":67,"lastName":"George","length":311.92771,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Stronger","status":200,"ts":1543518896796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Against Me!","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":45,"lastName":"Martinez","length":129.43628,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Clich\u00c3\u0083\u00c2\u00a9 Guevara","status":200,"ts":1543518933796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":46,"lastName":"Martinez","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"Logout","registration":1540646838796.0,"sessionId":1017,"song":null,"status":307,"ts":1543518934796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":47,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1017,"song":null,"status":200,"ts":1543518958796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":48,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":1017,"song":null,"status":307,"ts":1543518959796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":71,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Downgrade","registration":1540940782796.0,"sessionId":1041,"song":null,"status":200,"ts":1543519085796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":49,"lastName":"Martinez","length":null,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1540646838796.0,"sessionId":1017,"song":null,"status":200,"ts":1543519168796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Rah Digga","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":68,"lastName":"George","length":384.10404,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Imperial (LP Amended Version)","status":200,"ts":1543519207796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Pat Metheny Group","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":50,"lastName":"Martinez","length":324.8322,"level":"paid","location":"Atlanta-Sandy Springs-Roswell, GA","method":"PUT","page":"NextSong","registration":1540646838796.0,"sessionId":1017,"song":"Always and Forever","status":200,"ts":1543519479796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_3) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"82"} {"artist":"Harmonia","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":69,"lastName":"George","length":655.77751,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Sehr kosmisch","status":200,"ts":1543519591796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1048,"song":null,"status":200,"ts":1543519677796,"userAgent":null,"userId":""} {"artist":"David Lee Roth","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":70,"lastName":"George","length":171.83302,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"California Girls (Album Version)","status":200,"ts":1543520246796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Michael Cretu","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":71,"lastName":"George","length":301.06077,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"The Invisible Man","status":200,"ts":1543520417796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Haloo Helsinki!","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":72,"lastName":"George","length":223.42485,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":983,"song":"Kaaos ei karkaa","status":200,"ts":1543520718796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1065,"song":null,"status":200,"ts":1543520732796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":1065,"song":null,"status":307,"ts":1543520733796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":2,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":1065,"song":null,"status":200,"ts":1543521370796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Chali 2na","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":72,"lastName":"Cuevas","length":176.8224,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"MC Material","status":200,"ts":1543521962796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Radiohead","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":73,"lastName":"Cuevas","length":129.56689,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Faust Arp","status":200,"ts":1543522138796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Andre Hazes","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":74,"lastName":"Cuevas","length":206.70649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Droomland (duet met Paul de Leeuw)","status":200,"ts":1543522267796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Rise Against","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":75,"lastName":"Cuevas","length":242.25914,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Savior","status":200,"ts":1543522473796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sepultura","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":76,"lastName":"Cuevas","length":186.5922,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Ostia","status":200,"ts":1543522715796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Screaming Trees","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":77,"lastName":"Cuevas","length":218.30485,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Witness","status":200,"ts":1543522901796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Spencer Davis Group","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":78,"lastName":"Cuevas","length":244.94975,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Crossfire","status":200,"ts":1543523119796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Lionel Richie","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":79,"lastName":"Cuevas","length":310.69995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Still","status":200,"ts":1543523363796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Skinlab","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":80,"lastName":"Cuevas","length":277.89016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"So Far From The Truth","status":200,"ts":1543523673796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Larry Sparks","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":3,"lastName":"Levine","length":265.50812,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Follow The Star","status":200,"ts":1543523921796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Eastmountainsouth","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":81,"lastName":"Cuevas","length":237.58322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"You Dance","status":200,"ts":1543523950796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bon Jovi","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":4,"lastName":"Levine","length":228.85832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Have A Nice Day","status":200,"ts":1543524186796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Diam's","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":82,"lastName":"Cuevas","length":220.62975,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"La Boulette (G\u00c3\u0083\u00c2\u00a9n\u00c3\u0083\u00c2\u00a9ration Nan Nan)","status":200,"ts":1543524187796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Porcupine Tree","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":83,"lastName":"Cuevas","length":263.60118,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Blackest Eyes (Album Version)","status":200,"ts":1543524407796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Blackfield","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":5,"lastName":"Levine","length":311.82322,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Once","status":200,"ts":1543524414796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kate Bush","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":84,"lastName":"Cuevas","length":177.05751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Kite","status":200,"ts":1543524670796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Clinic","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":6,"lastName":"Levine","length":156.21179,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Walking With Thee","status":200,"ts":1543524725796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Muse","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":85,"lastName":"Cuevas","length":277.31546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Darkshines [Live From Le Zenith]","status":200,"ts":1543524847796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Shakira","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":7,"lastName":"Levine","length":322.79465,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"T\u00c3\u0083\u00c2\u00ba","status":200,"ts":1543524881796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Jellyfish","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":86,"lastName":"Cuevas","length":143.17669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Sebrina_ Paste And Plato","status":200,"ts":1543525124796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Verve","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":8,"lastName":"Levine","length":360.25424,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Bitter Sweet Symphony","status":200,"ts":1543525203796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Toro Y Moi","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":87,"lastName":"Cuevas","length":133.85098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Lissoms","status":200,"ts":1543525267796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Simon Harris","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":88,"lastName":"Cuevas","length":195.83955,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Sample Track 2","status":200,"ts":1543525400796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":9,"lastName":"Levine","length":197.51138,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Figure.09 (Album Version)","status":200,"ts":1543525563796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Michael W. Smith","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":89,"lastName":"Cuevas","length":381.88363,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"The Wonderful Cross","status":200,"ts":1543525595796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Underworld","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":10,"lastName":"Levine","length":329.53424,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Teardrop","status":200,"ts":1543525760796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Nickelback","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":90,"lastName":"Cuevas","length":274.65098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"This Afternoon (Album Version)","status":200,"ts":1543525976796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":0,"lastName":"Johnson","length":null,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"GET","page":"Home","registration":1541081807796.0,"sessionId":1008,"song":null,"status":200,"ts":1543525996796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":null,"auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":1,"lastName":"Johnson","length":null,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"GET","page":"Settings","registration":1541081807796.0,"sessionId":1008,"song":null,"status":200,"ts":1543526007796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"Jackson Do Pandeiro","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":2,"lastName":"Johnson","length":157.51791,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":1008,"song":"O Canto Da Ema","status":200,"ts":1543526056796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"John Mayer","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":11,"lastName":"Levine","length":269.71383,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Heartbreak Warfare","status":200,"ts":1543526089796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Triumvirat","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":3,"lastName":"Johnson","length":294.81751,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":1008,"song":"Waterfall","status":200,"ts":1543526213796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"Hausmylly","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":91,"lastName":"Cuevas","length":207.75138,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"TAVALLINEN TARINA","status":200,"ts":1543526250796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Thousand Foot Krutch","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":12,"lastName":"Levine","length":180.58404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Step To Me","status":200,"ts":1543526358796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Enya","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":92,"lastName":"Cuevas","length":218.53995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Only Time (Original Version)","status":200,"ts":1543526457796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Billie The Vision & The Dancers","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":4,"lastName":"Johnson","length":136.46322,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":1008,"song":"Still be Friends","status":200,"ts":1543526507796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"Claudio Minore","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":13,"lastName":"Levine","length":282.01751,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Non Saprai Mai","status":200,"ts":1543526538796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Charttraxx Karaoke","auth":"Logged In","firstName":"Martin","gender":"M","itemInSession":5,"lastName":"Johnson","length":225.17506,"level":"free","location":"Minneapolis-St. Paul-Bloomington, MN-WI","method":"PUT","page":"NextSong","registration":1541081807796.0,"sessionId":1008,"song":"Fireflies","status":200,"ts":1543526643796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"55"} {"artist":"The Radio Dept.","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":93,"lastName":"Cuevas","length":193.72363,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"The Worst Taste In Music (Extended)","status":200,"ts":1543526675796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Wilco","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":14,"lastName":"Levine","length":227.65669,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"War on war","status":200,"ts":1543526820796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"O-Zone","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":94,"lastName":"Cuevas","length":226.16771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Despre tine","status":200,"ts":1543526868796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Adam Lambert","auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":0,"lastName":"Rosales","length":227.39546,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541059521796.0,"sessionId":967,"song":"Whataya Want From Me","status":200,"ts":1543526870796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":null,"auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":1,"lastName":"Rosales","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"Logout","registration":1541059521796.0,"sessionId":967,"song":null,"status":307,"ts":1543526871796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":2,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":967,"song":null,"status":200,"ts":1543526901796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":3,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":967,"song":null,"status":307,"ts":1543526902796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":4,"lastName":"Rosales","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1541059521796.0,"sessionId":967,"song":null,"status":200,"ts":1543526969796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"Mission Of Burma","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":15,"lastName":"Levine","length":218.20036,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Red","status":200,"ts":1543527047796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Danity Kane","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":95,"lastName":"Cuevas","length":247.74485,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1041,"song":"Damaged [Feat. Fabolous]","status":200,"ts":1543527094796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":0,"lastName":"Scott","length":null,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"GET","page":"Home","registration":1540872073796.0,"sessionId":1010,"song":null,"status":200,"ts":1543527215796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Radiohead","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":16,"lastName":"Levine","length":223.00689,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Sulk","status":200,"ts":1543527265796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Fightstar","auth":"Logged In","firstName":"Wyatt","gender":"M","itemInSession":1,"lastName":"Scott","length":212.61016,"level":"free","location":"Eureka-Arcata-Fortuna, CA","method":"PUT","page":"NextSong","registration":1540872073796.0,"sessionId":1010,"song":"The English Way","status":200,"ts":1543527268796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; Trident\/7.0; rv:11.0) like Gecko","userId":"9"} {"artist":"Hoobastank","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":17,"lastName":"Levine","length":242.78159,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"To Be With You","status":200,"ts":1543527488796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Bright Eyes","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":18,"lastName":"Levine","length":279.87546,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Poison Oak (Album Version)","status":200,"ts":1543527730796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Procol Harum","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":19,"lastName":"Levine","length":368.56118,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Grand Hotel","status":200,"ts":1543528009796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Radiohead","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":20,"lastName":"Levine","length":259.29098,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Planet Telex","status":200,"ts":1543528377796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":21,"lastName":"Levine","length":195.94404,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Sincerit\u00c3\u0083\u00c2\u00a9 Et Jalousie","status":200,"ts":1543528636796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Muse","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":22,"lastName":"Levine","length":365.45261,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"New Born","status":200,"ts":1543528831796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Steps","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":23,"lastName":"Levine","length":201.76934,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"5_ 6_ 7_ 8","status":200,"ts":1543529196796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"John Mayer","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":24,"lastName":"Levine","length":198.19057,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"The Heart Of Life","status":200,"ts":1543529397796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Sean","gender":"F","itemInSession":0,"lastName":"Wilson","length":201.79546,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1540369554796.0,"sessionId":21,"song":"Revelry","status":200,"ts":1543529417796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"22"} {"artist":"David Gray","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":25,"lastName":"Levine","length":263.33995,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Draw The Line","status":200,"ts":1543529595796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"King Stitt","auth":"Logged In","firstName":"Sean","gender":"F","itemInSession":1,"lastName":"Wilson","length":176.27383,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"PUT","page":"NextSong","registration":1540369554796.0,"sessionId":21,"song":"The Ugly One (AKA Lee Van Cleef)","status":200,"ts":1543529618796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"22"} {"artist":"Tub Ring","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":26,"lastName":"Levine","length":233.69098,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Invalid","status":200,"ts":1543529858796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Era","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":27,"lastName":"Levine","length":200.56771,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Cathar Rhythm","status":200,"ts":1543530091796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":28,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":1065,"song":null,"status":200,"ts":1543530350796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"+ \/ - {Plus\/Minus}","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":29,"lastName":"Levine","length":318.98077,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"The Queen of Nothing","status":200,"ts":1543530451796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Crystal Castles","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":30,"lastName":"Levine","length":175.51628,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Good Time","status":200,"ts":1543530769796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The Whitest Boy Alive","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":31,"lastName":"Levine","length":234.57914,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Figures","status":200,"ts":1543530944796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The White Stripes","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":32,"lastName":"Levine","length":194.48118,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Bone Broke","status":200,"ts":1543531178796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Furthermore","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":33,"lastName":"Levine","length":211.69587,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Are You The Walrus?","status":200,"ts":1543531372796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Eminem \/ Bizarre","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":34,"lastName":"Levine","length":244.55791,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Amityville","status":200,"ts":1543531583796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":35,"lastName":"Levine","length":185.3122,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"I'm Not Calling You A Liar","status":200,"ts":1543531827796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Soda Stereo","auth":"Logged In","firstName":"Braden","gender":"M","itemInSession":0,"lastName":"Parker","length":316.73424,"level":"free","location":"Youngstown-Warren-Boardman, OH-PA","method":"PUT","page":"NextSong","registration":1540999292796.0,"sessionId":1007,"song":"Signos","status":200,"ts":1543531878796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"74"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":36,"lastName":"Levine","length":230.47791,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"You Belong With Me","status":200,"ts":1543532012796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":null,"auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":37,"lastName":"Levine","length":null,"level":"paid","location":"Portland-South Portland, ME","method":"GET","page":"Home","registration":1540794356796.0,"sessionId":1065,"song":null,"status":200,"ts":1543532195796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Pearl Jam","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":38,"lastName":"Levine","length":283.89832,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Rearviewmirror","status":200,"ts":1543532242796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"The 2 Live Crew","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":39,"lastName":"Levine","length":188.31628,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Me So Horny","status":200,"ts":1543532525796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"311","auth":"Logged In","firstName":"Tegan","gender":"F","itemInSession":40,"lastName":"Levine","length":113.26649,"level":"paid","location":"Portland-South Portland, ME","method":"PUT","page":"NextSong","registration":1540794356796.0,"sessionId":1065,"song":"Loco","status":200,"ts":1543532713796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"80"} {"artist":"Light Of The World","auth":"Logged In","firstName":"Kynnedi","gender":"F","itemInSession":0,"lastName":"Sanchez","length":207.0722,"level":"free","location":"Cedar Rapids, IA","method":"PUT","page":"NextSong","registration":1541079034796.0,"sessionId":1029,"song":"Midnight Groovin' (7\" Version) (2006 Digital Remaster)","status":200,"ts":1543533515796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_8_5) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"89"}
459.784153
588
0.698463
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"artist":"Stephen Lynch","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Bell","length":182.85669,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540991795796.0,"sessionId":829,"song":"Jim Henson's Dead","status":200,"ts":1543537327796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 10.0; Windows NT 6.2; WOW64; Trident\/6.0)","userId":"91"} {"artist":"Manowar","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":0,"lastName":"Klein","length":247.562,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"Shell Shock","status":200,"ts":1543540121796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Morcheeba","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":1,"lastName":"Klein","length":257.41016,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"Women Lose Weight (Feat: Slick Rick)","status":200,"ts":1543540368796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Maroon 5","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":2,"lastName":"Klein","length":231.23546,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"Won't Go Home Without You","status":200,"ts":1543540625796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Train","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":3,"lastName":"Klein","length":216.76363,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"Hey_ Soul Sister","status":200,"ts":1543540856796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"LMFAO","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":4,"lastName":"Klein","length":227.99628,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"I'm In Miami Bitch","status":200,"ts":1543541072796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"DJ Dizzy","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":5,"lastName":"Klein","length":221.1522,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"Sexy Bitch","status":200,"ts":1543541299796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Fish Go Deep & Tracey K","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":6,"lastName":"Klein","length":377.41669,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"The Cure & The Cause (Dennis Ferrer Remix)","status":200,"ts":1543541520796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Alivia","gender":"F","itemInSession":0,"lastName":"Terrell","length":null,"level":"free","location":"Parkersburg-Vienna, WV","method":"GET","page":"Home","registration":1540505391796.0,"sessionId":1070,"song":null,"status":200,"ts":1543541644796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"4"} {"artist":"M83","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":7,"lastName":"Klein","length":96.1824,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"Staring At Me","status":200,"ts":1543541897796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Saybia","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":8,"lastName":"Klein","length":257.25342,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"The Second You Sleep","status":200,"ts":1543541993796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Local Natives","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":9,"lastName":"Klein","length":266.05669,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"Wide Eyes","status":200,"ts":1543542250796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"South Park","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":10,"lastName":"Klein","length":112.97914,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"La Resistance (Medley) (LP Version)","status":200,"ts":1543542516796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"UNKLE Feat. Josh Homme","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":11,"lastName":"Klein","length":307.19955,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"Restless","status":200,"ts":1543542628796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Justyna Steczkowska","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":12,"lastName":"Klein","length":333.53098,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"Noc...","status":200,"ts":1543542935796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Evanescence","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":13,"lastName":"Klein","length":256.91383,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"Like You","status":200,"ts":1543543268796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Coldplay","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":14,"lastName":"Klein","length":297.35138,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"God Put A Smile Upon Your Face","status":200,"ts":1543543524796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Hot Chip","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":15,"lastName":"Klein","length":333.50485,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"Playboy","status":200,"ts":1543543821796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Ellie Goulding","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":16,"lastName":"Klein","length":205.06077,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"Every Time You Go","status":200,"ts":1543544154796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":"Postal Service","auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":17,"lastName":"Klein","length":307.53914,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"NextSong","registration":1540558108796.0,"sessionId":1049,"song":"Natural Anthem (Album)","status":200,"ts":1543544359796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged In","firstName":"Jacob","gender":"M","itemInSession":18,"lastName":"Klein","length":null,"level":"paid","location":"Tampa-St. Petersburg-Clearwater, FL","method":"PUT","page":"Logout","registration":1540558108796.0,"sessionId":1049,"song":null,"status":307,"ts":1543544360796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.78.2 (KHTML, like Gecko) Version\/7.0.6 Safari\/537.78.2\"","userId":"73"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":19,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1049,"song":null,"status":200,"ts":1543544407796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":0,"lastName":"Hess","length":null,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"GET","page":"Home","registration":1540829025796.0,"sessionId":986,"song":null,"status":200,"ts":1543547152796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":1,"lastName":"Hess","length":240.06485,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":986,"song":"Taylor","status":200,"ts":1543547190796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Iron And Wine","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":2,"lastName":"Hess","length":153.05098,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":986,"song":"Naked As We Can","status":200,"ts":1543547430796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"The xx","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":3,"lastName":"Hess","length":158.24934,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":986,"song":"Fantasy","status":200,"ts":1543547583796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"The Antlers","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":4,"lastName":"Hess","length":328.88118,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":986,"song":"Epilogue","status":200,"ts":1543547741796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":"Fattburger","auth":"Logged In","firstName":"Aiden","gender":"M","itemInSession":5,"lastName":"Hess","length":217.20771,"level":"free","location":"La Crosse-Onalaska, WI-MN","method":"PUT","page":"NextSong","registration":1540829025796.0,"sessionId":986,"song":"Groovin'","status":200,"ts":1543548069796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/37.0.2062.94 Safari\/537.36\"","userId":"86"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":0,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":1051,"song":null,"status":200,"ts":1543548391796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":1,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Settings","registration":1541057188796.0,"sessionId":1051,"song":null,"status":200,"ts":1543548494796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Chris Brown","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":2,"lastName":"Griffin","length":203.80689,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"Ain't No Way (You Won't Love Me)","status":200,"ts":1543548563796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Phoenix","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":3,"lastName":"Griffin","length":278.07302,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"Rome","status":200,"ts":1543548766796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":4,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Home","registration":1541057188796.0,"sessionId":1051,"song":null,"status":200,"ts":1543548833796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Jim Lauderdale\/Ralph Stanley & The Clinch Mountain Boys","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":5,"lastName":"Griffin","length":127.05914,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"Highway Through My Home","status":200,"ts":1543549044796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":6,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Settings","registration":1541057188796.0,"sessionId":1051,"song":null,"status":200,"ts":1543549070796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Musiq","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":7,"lastName":"Griffin","length":297.84771,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"143","status":200,"ts":1543549171796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Cass McCombs feat. Karen Black","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":8,"lastName":"Griffin","length":322.06322,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"Dreams-Come-True-Girl","status":200,"ts":1543549468796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":9,"lastName":"Griffin","length":null,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"GET","page":"Downgrade","registration":1541057188796.0,"sessionId":1051,"song":null,"status":200,"ts":1543549506796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Scissor Sisters","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":10,"lastName":"Griffin","length":352.522,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"I Don't Feel Like Dancin'","status":200,"ts":1543549790796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"O.A.R.","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":11,"lastName":"Griffin","length":315.74159,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"Right On Time (Album Version)","status":200,"ts":1543550142796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"1 Mile North","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":352.73098,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1068,"song":"Black Lines","status":200,"ts":1543550301796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Muse","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":12,"lastName":"Griffin","length":304.84853,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"Uprising","status":200,"ts":1543550457796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"USS (Ubiquitous Synergy Seeker)","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":307.61751,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1068,"song":"Man Makes The Zoo","status":200,"ts":1543550653796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"The Psychedelic Furs","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":13,"lastName":"Griffin","length":417.07057,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"Blacks\/Radio","status":200,"ts":1543550761796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Esm\u00c3\u0083\u00c2\u00a9e Denters \/ Justin Timberlake","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":2,"lastName":"Smith","length":227.52608,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1068,"song":"Love Dealer (Featuring Justin Timberlake)","status":200,"ts":1543550960796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":14,"lastName":"Griffin","length":252.21179,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"Repr\u00c3\u0083\u00c2\u00a9sente","status":200,"ts":1543551178796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Train","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":3,"lastName":"Smith","length":216.76363,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1068,"song":"Hey_ Soul Sister","status":200,"ts":1543551187796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":4,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1541016707796.0,"sessionId":1068,"song":null,"status":200,"ts":1543551235796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Hoobastank","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":15,"lastName":"Griffin","length":202.57914,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"Up And Gone","status":200,"ts":1543551430796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":null,"auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":5,"lastName":"Smith","length":null,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Settings","registration":1541016707796.0,"sessionId":1068,"song":null,"status":200,"ts":1543551476796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Ismael Serrano","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":16,"lastName":"Griffin","length":179.35628,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"Te Conoci","status":200,"ts":1543551632796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"The Pussycat Dolls \/ Snoop Dogg","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":6,"lastName":"Smith","length":210.31138,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1068,"song":"Bottle Pop","status":200,"ts":1543551680796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Dierks Bentley","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":17,"lastName":"Griffin","length":198.63465,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"My Love Will Follow You","status":200,"ts":1543551811796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"59 Times the Pain","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":7,"lastName":"Smith","length":144.95302,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1068,"song":"Found Home","status":200,"ts":1543551890796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":18,"lastName":"Griffin","length":259.86567,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"My December","status":200,"ts":1543552009796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"New Order","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":8,"lastName":"Smith","length":288.05179,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1068,"song":"The Perfect Kiss","status":200,"ts":1543552034796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Madeleine Peyroux","auth":"Logged In","firstName":"Layla","gender":"F","itemInSession":19,"lastName":"Griffin","length":206.18404,"level":"paid","location":"Lake Havasu City-Kingman, AZ","method":"PUT","page":"NextSong","registration":1541057188796.0,"sessionId":1051,"song":"You're Gonna Make Me Lonesome When You Go","status":200,"ts":1543552268796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"24"} {"artist":"Bow Wow feat. Chris Brown and Johnt\u00c3\u0083\u00c2\u00a1 Austin","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":9,"lastName":"Smith","length":268.06812,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1068,"song":"Shortie Like Mine","status":200,"ts":1543552322796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Symphony X","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":10,"lastName":"Smith","length":389.45914,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1068,"song":"Domination","status":200,"ts":1543552590796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Minnie Riperton","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":238.73261,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Inside My Love (Digitally Remastered 93)","status":200,"ts":1543552925796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Custom Blue","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":346.51383,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Structure","status":200,"ts":1543553163796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Rage Against The Machine","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":314.40934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Killing In The Name","status":200,"ts":1543553509796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Milli Vanilli","auth":"Logged In","firstName":"Katherine","gender":"F","itemInSession":0,"lastName":"Gay","length":197.92934,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540968306796.0,"sessionId":1020,"song":"Girl You Know It's True","status":200,"ts":1543553771796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_6_8) AppleWebKit\/534.59.10 (KHTML, like Gecko) Version\/5.1.9 Safari\/534.59.10\"","userId":"57"} {"artist":"David Arkenstone","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":363.41506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Waterfall (Spirit Of The Rainforest Album Version)","status":200,"ts":1543553823796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cosmo Vitelli","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":206.05342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Robot Soul (Radio Edit)","status":200,"ts":1543554186796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Morcheeba","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":277.4722,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Blindfold","status":200,"ts":1543554392796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":243.48689,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"I'm Yours (Album Version)","status":200,"ts":1543554669796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":0,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1540871783796.0,"sessionId":884,"song":null,"status":200,"ts":1543554697796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":1,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Downgrade","registration":1540871783796.0,"sessionId":884,"song":null,"status":200,"ts":1543554706796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Deep Dish","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":2,"lastName":"Watkins","length":274.28526,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"Say Hello","status":200,"ts":1543554740796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Cutting Crew","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":263.07873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"(I Just) Died In Your Arms","status":200,"ts":1543554912796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Velvet Underground","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":3,"lastName":"Watkins","length":240.66567,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"Sweet Jane","status":200,"ts":1543555014796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Future Rock","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":239.90812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Gears","status":200,"ts":1543555175796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The White Stripes","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":4,"lastName":"Watkins","length":231.81016,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"Seven Nation Army (Album Version)","status":200,"ts":1543555254796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Coldplay","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":294.1122,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Fix You","status":200,"ts":1543555414796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Portishead","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":5,"lastName":"Watkins","length":259.99628,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"It Could Be Sweet","status":200,"ts":1543555485796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Thelma Houston","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":196.51873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"If This Was The Last Song","status":200,"ts":1543555708796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Chicane","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":6,"lastName":"Watkins","length":223.92118,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"Poppiholla","status":200,"ts":1543555744796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":0,"lastName":"Smith","length":null,"level":"free","location":"Palestine, TX","method":"GET","page":"Home","registration":1540685147796.0,"sessionId":1006,"song":null,"status":200,"ts":1543555869796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Metallica","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":1,"lastName":"Smith","length":466.54649,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":1006,"song":"The Unforgiven III","status":200,"ts":1543555885796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Jennifer Lopez","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":301.34812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Apresurate","status":200,"ts":1543555904796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Box Car Racer","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":7,"lastName":"Watkins","length":196.93669,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"There Is","status":200,"ts":1543555967796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Robin Thicke","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":8,"lastName":"Watkins","length":216.68526,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"Would That Make U Love Me","status":200,"ts":1543556163796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Dashboard Confessional","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":226.29832,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Screaming Infidelities","status":200,"ts":1543556205796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Radney Foster","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":9,"lastName":"Watkins","length":205.84444,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"Big Idea","status":200,"ts":1543556379796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":10,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Home","registration":1540871783796.0,"sessionId":884,"song":null,"status":200,"ts":1543556386796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"La Roux","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":205.60934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Bulletproof","status":200,"ts":1543556431796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Wax Tailor","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":11,"lastName":"Watkins","length":177.68444,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"The Tune","status":200,"ts":1543556584796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":300.56444,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Trani","status":200,"ts":1543556636796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kix","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":12,"lastName":"Watkins","length":246.25587,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"Girl Money","status":200,"ts":1543556761796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Mother Love Bone","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":495.72526,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Chloe Dancer\/Crown Of Thorns","status":200,"ts":1543556936796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Decemberists","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":13,"lastName":"Watkins","length":252.81261,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"The Bachelor and the Bride","status":200,"ts":1543557007796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Telefon Tel Aviv","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":14,"lastName":"Watkins","length":222.09261,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"M","status":200,"ts":1543557259796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"B.o.B","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":269.63546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Nothin' On You [feat. Bruno Mars] (Album Version)","status":200,"ts":1543557431796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":15,"lastName":"Watkins","length":409.96526,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"You Sent Me Flying \/ Cherry","status":200,"ts":1543557481796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Anabelle","gender":"F","itemInSession":0,"lastName":"Simpson","length":null,"level":"free","location":"Philadelphia-Camden-Wilmington, PA-NJ-DE-MD","method":"GET","page":"Home","registration":1541044398796.0,"sessionId":1022,"song":null,"status":200,"ts":1543557623796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"69"} {"artist":"BEFORE THE DAWN","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":17,"lastName":"Cuevas","length":195.65669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Faithless","status":200,"ts":1543557700796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Strokes","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":16,"lastName":"Watkins","length":187.34975,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"You Only Live Once","status":200,"ts":1543557890796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Animals As Leaders","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":18,"lastName":"Cuevas","length":323.83955,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Tempting Time","status":200,"ts":1543557895796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Mazzy Star","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":17,"lastName":"Watkins","length":297.9522,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"Flowers In December","status":200,"ts":1543558077796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Cream","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":19,"lastName":"Cuevas","length":185.44281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Take It Back","status":200,"ts":1543558218796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"M\u00c3\u0083\u00c2\u00bam","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":18,"lastName":"Watkins","length":68.67546,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"Behind Two Hills&A Swimming Pool","status":200,"ts":1543558374796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"3OH!3","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":20,"lastName":"Cuevas","length":192.522,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"My First Kiss (Feat. Ke$ha) [Album Version]","status":200,"ts":1543558403796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"N.W.A.","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":19,"lastName":"Watkins","length":266.26567,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"Straight Outta Compton (Extended Mix) (Edit) (Explicit)","status":200,"ts":1543558442796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Dan Auerbach","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":21,"lastName":"Cuevas","length":296.95955,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Goin' Home","status":200,"ts":1543558595796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Lagwagon","auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":20,"lastName":"Watkins","length":173.322,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1540871783796.0,"sessionId":884,"song":"Sick","status":200,"ts":1543558708796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":null,"auth":"Logged In","firstName":"Avery","gender":"F","itemInSession":21,"lastName":"Watkins","length":null,"level":"paid","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"GET","page":"Downgrade","registration":1540871783796.0,"sessionId":884,"song":null,"status":200,"ts":1543558710796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"30"} {"artist":"Coldplay","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":22,"lastName":"Cuevas","length":294.1122,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Fix You","status":200,"ts":1543558891796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"John Mayer","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":23,"lastName":"Cuevas","length":250.38322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Half Of My Heart","status":200,"ts":1543559185796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":24,"lastName":"Cuevas","length":201.79546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Revelry","status":200,"ts":1543559435796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ashbury Heights","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":25,"lastName":"Cuevas","length":198.60853,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"World Coming Down","status":200,"ts":1543559636796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Scooter","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":26,"lastName":"Cuevas","length":213.02812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Fire","status":200,"ts":1543559834796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Boy Kill Boy","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":27,"lastName":"Cuevas","length":220.47302,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Shoot Me Down","status":200,"ts":1543560047796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eric B. & Rakim","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":28,"lastName":"Cuevas","length":241.60608,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Juice (Know The Ledge)","status":200,"ts":1543560267796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Josh Groban","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":29,"lastName":"Cuevas","length":243.40853,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Hymne A L'Amour (Album Version)","status":200,"ts":1543560508796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bad Religion","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":30,"lastName":"Cuevas","length":131.86567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"We're Only Gonna Die (Album Version)","status":200,"ts":1543560751796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Tempa T","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":31,"lastName":"Cuevas","length":236.35546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Next Hype","status":200,"ts":1543560882796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Charttraxx Karaoke","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":32,"lastName":"Cuevas","length":225.17506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Fireflies","status":200,"ts":1543561118796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eagles","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":33,"lastName":"Cuevas","length":372.29669,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Hotel California","status":200,"ts":1543561343796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eric Clapton","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":34,"lastName":"Cuevas","length":409.57342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Little Wing","status":200,"ts":1543561715796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Spineshank","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":35,"lastName":"Cuevas","length":187.6371,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Smothered (Album Version)","status":200,"ts":1543562124796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kaiser Chiefs","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":36,"lastName":"Cuevas","length":221.07383,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Try Your Best","status":200,"ts":1543562311796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dominique A","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":37,"lastName":"Cuevas","length":153.20771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Le Courage Des Oiseaux","status":200,"ts":1543562532796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kill Hannah","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":38,"lastName":"Cuevas","length":224.49587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Lips Like Morphine (Album Version)","status":200,"ts":1543562685796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"I:gor","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":39,"lastName":"Cuevas","length":190.27546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Kiedys zrozumiesz","status":200,"ts":1543562909796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The All-American Rejects","auth":"Logged In","firstName":"Braden","gender":"M","itemInSession":0,"lastName":"Parker","length":206.96771,"level":"free","location":"Youngstown-Warren-Boardman, OH-PA","method":"PUT","page":"NextSong","registration":1540999292796.0,"sessionId":1082,"song":"Fallin' Apart","status":200,"ts":1543562949796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"74"} {"artist":"Guns N' Roses","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":40,"lastName":"Cuevas","length":284.05506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Don't Cry (Original)","status":200,"ts":1543563099796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"White Denim","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":41,"lastName":"Cuevas","length":148.55791,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Transparency","status":200,"ts":1543563383796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"El Canto del Loco","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":42,"lastName":"Cuevas","length":226.0371,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"La Suerte De Mi Vida","status":200,"ts":1543563531796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Grinderswitch","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":43,"lastName":"Cuevas","length":268.2771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Redwing","status":200,"ts":1543563757796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Donovan","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":44,"lastName":"Cuevas","length":169.22077,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Starfish-On-The-Toast (2008 Digital Remaster)","status":200,"ts":1543564025796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"As I Lay Dying","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":45,"lastName":"Cuevas","length":348.1073,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1079,"song":"Illusions","status":200,"ts":1543564194796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1075,"song":null,"status":200,"ts":1543565471796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":1075,"song":null,"status":307,"ts":1543565472796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":1075,"song":null,"status":200,"ts":1543565676796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"matchbox twenty","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":3,"lastName":"Rodriguez","length":241.34485,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":1075,"song":"Bright Lights (Remastered Version)","status":200,"ts":1543565771796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Kinky","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":4,"lastName":"Rodriguez","length":105.32526,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":1075,"song":"Field Goal","status":200,"ts":1543566012796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Shania Twain","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":5,"lastName":"Rodriguez","length":250.51383,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":1075,"song":"Nah!","status":200,"ts":1543566117796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Hinder","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":6,"lastName":"Rodriguez","length":231.73179,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":1075,"song":"By The Way","status":200,"ts":1543566367796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Spencer Davis Group","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":7,"lastName":"Rodriguez","length":165.27628,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":1075,"song":"Keep On Running","status":200,"ts":1543566598796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"SOJA","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":8,"lastName":"Rodriguez","length":355.89179,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":1075,"song":"I Dont Wanna Wait","status":200,"ts":1543566763796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Infected Mushroom","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":9,"lastName":"Rodriguez","length":463.72526,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":1075,"song":"Echonomix","status":200,"ts":1543567118796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Unkle Bob","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":10,"lastName":"Rodriguez","length":160.10404,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":1075,"song":"One By One","status":200,"ts":1543567581796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":11,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"Logout","registration":1540511766796.0,"sessionId":1075,"song":null,"status":307,"ts":1543567582796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":12,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1075,"song":null,"status":200,"ts":1543567614796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":0,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Home","registration":1541062818796.0,"sessionId":998,"song":null,"status":200,"ts":1543572735796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Alex Ubago","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":1,"lastName":"Jones","length":313.28608,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Sin Miedo a Nada (con Amaia Montero)","status":200,"ts":1543572774796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Twilight Singers","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":2,"lastName":"Jones","length":286.53669,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Bonnie Brae","status":200,"ts":1543573087796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Chikita Violenta","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":3,"lastName":"Jones","length":255.92118,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"War","status":200,"ts":1543573373796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Cat Stevens","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":4,"lastName":"Jones","length":225.17506,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Sad Lisa","status":200,"ts":1543573628796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Kenny Garrett","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":5,"lastName":"Jones","length":265.19465,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"The House That Nat Built (Album Version)","status":200,"ts":1543573853796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"You Me At Six","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":6,"lastName":"Jones","length":216.68526,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Jealous Minds Think Alike","status":200,"ts":1543574118796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Nellie Lutcher","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":7,"lastName":"Jones","length":195.70893,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"My Mother's Eyes","status":200,"ts":1543574334796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Kid Cudi \/ Kanye West \/ Common","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":8,"lastName":"Jones","length":237.76608,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Make Her Say","status":200,"ts":1543574529796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Tiro De Gracia","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":9,"lastName":"Jones","length":214.83057,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Viaje Sin Rumbo (2004 Digital Remaster)","status":200,"ts":1543574766796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"polarkreis 18","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":10,"lastName":"Jones","length":265.29914,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Dreamdancer","status":200,"ts":1543574980796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"+ \/ - {Plus\/Minus}","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":11,"lastName":"Jones","length":318.98077,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"The Queen of Nothing","status":200,"ts":1543575245796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Dr Feelgood","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":0,"lastName":"Smith","length":216.13669,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":1092,"song":"Riot In Cell Block Number Nine","status":200,"ts":1543575385796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Harmonia","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":12,"lastName":"Jones","length":655.77751,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Sehr kosmisch","status":200,"ts":1543575563796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Chimaira","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":1,"lastName":"Smith","length":377.36444,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":1092,"song":"Everything You Love (Album Version)","status":200,"ts":1543575601796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Joshua Radin","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":2,"lastName":"Smith","length":211.27791,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":1092,"song":"Someone Else's Life","status":200,"ts":1543575978796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"Bajaga & Instruktori","auth":"Logged In","firstName":"Ryann","gender":"F","itemInSession":3,"lastName":"Smith","length":254.95465,"level":"free","location":"Palestine, TX","method":"PUT","page":"NextSong","registration":1540685147796.0,"sessionId":1092,"song":"Godine prolaze","status":200,"ts":1543576189796,"userAgent":"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10.9; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"92"} {"artist":"The Virgins","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":13,"lastName":"Jones","length":169.37751,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Private Affair (Amended Album Version)","status":200,"ts":1543576218796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"SA Rawls \/ Still Flyin' \/ Still Flyin'","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":14,"lastName":"Jones","length":183.09179,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Ginko Biloba","status":200,"ts":1543576387796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Grown Ups","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":15,"lastName":"Jones","length":233.42975,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Three Day Weekend","status":200,"ts":1543576570796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Nancy Ajram","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":16,"lastName":"Jones","length":221.67465,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Meen Dah Elly Nseik","status":200,"ts":1543576803796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":972,"song":null,"status":200,"ts":1543576893796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"free","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":972,"song":null,"status":307,"ts":1543576894796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Kaylee","gender":"F","itemInSession":2,"lastName":"Summers","length":null,"level":"free","location":"Phoenix-Mesa-Scottsdale, AZ","method":"GET","page":"Home","registration":1540344794796.0,"sessionId":972,"song":null,"status":200,"ts":1543576912796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/35.0.1916.153 Safari\/537.36\"","userId":"8"} {"artist":"The Donkeys","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":17,"lastName":"Jones","length":272.19546,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Boot On The Seat","status":200,"ts":1543577024796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Datarock","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":18,"lastName":"Jones","length":228.49261,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"FaFaFa (Radio Edit)","status":200,"ts":1543577296796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Daft Punk","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":19,"lastName":"Jones","length":319.42485,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Human After All","status":200,"ts":1543577524796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":20,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Settings","registration":1541062818796.0,"sessionId":998,"song":null,"status":200,"ts":1543577767796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":21,"lastName":"Jones","length":220.89098,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Somebody To Love","status":200,"ts":1543577843796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Beach House","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":22,"lastName":"Jones","length":320.44363,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Real Love","status":200,"ts":1543578063796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"The Walkmen","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":23,"lastName":"Jones","length":199.36608,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Subterranean Homesick Blues (Album Version)","status":200,"ts":1543578383796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Busted \/ Charlie Simpson \/ Mattie Jay \/ James Bourne","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":24,"lastName":"Jones","length":252.83873,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":998,"song":"Can't Break Thru","status":200,"ts":1543578582796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Beyonc\u00c3\u0083\u00c2\u00a9","auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":0,"lastName":"Rosales","length":374.59546,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"PUT","page":"NextSong","registration":1541059521796.0,"sessionId":1078,"song":"Get Me Bodied","status":200,"ts":1543579857796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":1096,"song":null,"status":200,"ts":1543580824796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sick Puppies","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":209.44934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Maybe","status":200,"ts":1543581078796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"U2","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":289.2273,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Walk To The Water","status":200,"ts":1543581287796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ron Carter","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":497.13587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"I CAN'T GET STARTED","status":200,"ts":1543581576796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Duran Duran","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":297.63873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Breath After Breath","status":200,"ts":1543582073796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Tears For Fears","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":255.34649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Head Over Heels","status":200,"ts":1543582370796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":0,"lastName":"Gonzalez","length":null,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"GET","page":"Home","registration":1540492941796.0,"sessionId":1064,"song":null,"status":200,"ts":1543582604796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":277.10649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Lonely As You","status":200,"ts":1543582625796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Yellowcard","auth":"Logged In","firstName":"Samuel","gender":"M","itemInSession":1,"lastName":"Gonzalez","length":208.79628,"level":"free","location":"Houston-The Woodlands-Sugar Land, TX","method":"PUT","page":"NextSong","registration":1540492941796.0,"sessionId":1064,"song":"One Year_ Six Months","status":200,"ts":1543582673796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"61"} {"artist":"Big Tymers","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":252.05506,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Against The Wall","status":200,"ts":1543582902796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":1096,"song":null,"status":200,"ts":1543582902796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Enigma","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":262.71302,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Knocking On Forbidden Doors","status":200,"ts":1543583154796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dennis Ferrer","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":209.162,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Hey Hey","status":200,"ts":1543583416796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Justin Bieber","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":220.89098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Somebody To Love","status":200,"ts":1543583625796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Markus Kruneg\u00c3\u0083\u00c2\u00a5rd","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":185.5473,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Genom tunna tyger","status":200,"ts":1543583845796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Linkin Park","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":439.562,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"The Little Things Give You Away [Live At Milton Keynes]","status":200,"ts":1543584030796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jamie Cullum","auth":"Logged In","firstName":"Jahiem","gender":"M","itemInSession":0,"lastName":"Miles","length":204.25098,"level":"free","location":"San Antonio-New Braunfels, TX","method":"PUT","page":"NextSong","registration":1540817347796.0,"sessionId":618,"song":"Devil May Care","status":200,"ts":1543584044796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"43"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Help","registration":1540940782796.0,"sessionId":1096,"song":null,"status":200,"ts":1543584205796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Jordan","gender":"F","itemInSession":0,"lastName":"Rodriguez","length":null,"level":"free","location":"Los Angeles-Long Beach-Anaheim, CA","method":"GET","page":"Home","registration":1540992715796.0,"sessionId":902,"song":null,"status":200,"ts":1543584463796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"68"} {"artist":"Every Avenue","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":219.95057,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Tell Me I'm A Wreck","status":200,"ts":1543584469796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":201.63873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Constellations","status":200,"ts":1543584688796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Shakira","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":17,"lastName":"Cuevas","length":233.87383,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Vuelve","status":200,"ts":1543584889796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Maine","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":18,"lastName":"Cuevas","length":189.59628,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Give Me Anything","status":200,"ts":1543585122796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cannibal Corpse","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":19,"lastName":"Cuevas","length":209.00526,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Worm Infested","status":200,"ts":1543585311796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":977,"song":null,"status":200,"ts":1543585406796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":1,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":977,"song":null,"status":307,"ts":1543585407796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":2,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":977,"song":null,"status":200,"ts":1543585410796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Arcade Fire","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":3,"lastName":"Young","length":267.80689,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Headlights Look Like Diamonds","status":200,"ts":1543585420796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Black Eyed Peas","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":20,"lastName":"Cuevas","length":215.7971,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Hands Up","status":200,"ts":1543585520796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Radney Foster","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":4,"lastName":"Young","length":288.96608,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Sweet And Wild","status":200,"ts":1543585687796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Metric","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":21,"lastName":"Cuevas","length":222.85016,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Satellite Mind","status":200,"ts":1543585735796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":22,"lastName":"Cuevas","length":239.3073,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"You're The One","status":200,"ts":1543585957796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":5,"lastName":"Young","length":266.63138,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Did You Get My Message? (Live From Montalvo)","status":200,"ts":1543585975796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Kutt Calhoun","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":23,"lastName":"Cuevas","length":307.51302,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"N A Whitemanzeyez","status":200,"ts":1543586196796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Radiohead","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":6,"lastName":"Young","length":261.45914,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Karma Police","status":200,"ts":1543586241796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Molotov","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":0,"lastName":"Robinson","length":127.37261,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":1050,"song":"Puto","status":200,"ts":1543586244796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":null,"auth":"Logged In","firstName":"Cecilia","gender":"F","itemInSession":0,"lastName":"Owens","length":null,"level":"free","location":"Atlanta-Sandy Springs-Roswell, GA","method":"GET","page":"Home","registration":1541032432796.0,"sessionId":1027,"song":null,"status":200,"ts":1543586278796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; WOW64; rv:32.0) Gecko\/20100101 Firefox\/32.0","userId":"6"} {"artist":"The Strokes","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":1,"lastName":"Robinson","length":230.1122,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":1050,"song":"Killing Lies","status":200,"ts":1543586371796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Rufus Wainwright","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":0,"lastName":"Smith","length":249.62567,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1090,"song":"Hallelujah","status":200,"ts":1543586438796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Deadmau5","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":7,"lastName":"Young","length":374.20363,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Ghosts 'n' Stuff (Original Instrumental Mix)","status":200,"ts":1543586502796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"John Farnham","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":24,"lastName":"Cuevas","length":300.72118,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"You're The Voice","status":200,"ts":1543586503796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Infant Sorrow","auth":"Logged In","firstName":"Ava","gender":"F","itemInSession":2,"lastName":"Robinson","length":170.16118,"level":"free","location":"New Haven-Milford, CT","method":"PUT","page":"NextSong","registration":1540931983796.0,"sessionId":1050,"song":"Inside Of You","status":200,"ts":1543586601796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"50"} {"artist":"Betty Wright","auth":"Logged In","firstName":"Ryan","gender":"M","itemInSession":1,"lastName":"Smith","length":164.85832,"level":"free","location":"San Jose-Sunnyvale-Santa Clara, CA","method":"PUT","page":"NextSong","registration":1541016707796.0,"sessionId":1090,"song":"Clean Up Woman (Single\/LP Version)","status":200,"ts":1543586687796,"userAgent":"\"Mozilla\/5.0 (X11; Linux x86_64) AppleWebKit\/537.36 (KHTML, like Gecko) Ubuntu Chromium\/36.0.1985.125 Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"26"} {"artist":"Guus Meeuwis","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":25,"lastName":"Cuevas","length":198.42567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Tranen Gelachen","status":200,"ts":1543586803796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Muse","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":8,"lastName":"Young","length":209.00526,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"The Small Print","status":200,"ts":1543586876796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Estrella Morente","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":26,"lastName":"Cuevas","length":135.70567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"A Qu\u00c3\u0083\u00c2\u00a9 Niegas El Delirio (Malague\u00c3\u0083\u00c2\u00b1a) (Live)","status":200,"ts":1543587001796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dr. Alban","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":9,"lastName":"Young","length":240.14322,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"It's My Life (Radio Edit)","status":200,"ts":1543587085796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Radiohead","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":27,"lastName":"Cuevas","length":260.0224,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Sit Down. Stand Up","status":200,"ts":1543587136796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Mondo Marcio","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":10,"lastName":"Young","length":263.60118,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Purple Weed","status":200,"ts":1543587325796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Mae","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":28,"lastName":"Cuevas","length":309.15873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Someone Else's Arms","status":200,"ts":1543587396796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Meat Loaf \/ Jennifer Hudson","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":11,"lastName":"Young","length":474.01751,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"The Future Ain't What It Used To Be","status":200,"ts":1543587588796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Vampire Weekend","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":29,"lastName":"Cuevas","length":137.82159,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"A-Punk (Album)","status":200,"ts":1543587705796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"MGMT","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":30,"lastName":"Cuevas","length":264.17587,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Time To Pretend","status":200,"ts":1543587842796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Federico Aubele","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":12,"lastName":"Young","length":213.65506,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Luna y Sol","status":200,"ts":1543588062796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Jesse Rose","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":31,"lastName":"Cuevas","length":313.15546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Touch My Horn","status":200,"ts":1543588106796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Orion","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":13,"lastName":"Young","length":292.70159,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Eternity","status":200,"ts":1543588275796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":14,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"Logout","registration":1540465241796.0,"sessionId":977,"song":null,"status":307,"ts":1543588276796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":15,"lastName":null,"length":null,"level":"paid","location":null,"method":"GET","page":"Home","registration":null,"sessionId":977,"song":null,"status":200,"ts":1543588286796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":16,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":977,"song":null,"status":307,"ts":1543588287796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":17,"lastName":"Young","length":null,"level":"paid","location":"Red Bluff, CA","method":"GET","page":"Home","registration":1540465241796.0,"sessionId":977,"song":null,"status":200,"ts":1543588316796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Circa Survive","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":32,"lastName":"Cuevas","length":298.70975,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Dyed in the Wool (Album Version)","status":200,"ts":1543588419796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Wretch 32_ Vis","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":243.35628,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":1060,"song":"Wretchrospective (feat. Vis)","status":200,"ts":1543588433796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Simian Mobile Disco","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":18,"lastName":"Young","length":354.61179,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Simple","status":200,"ts":1543588567796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Erdm\u00c3\u0083\u00c2\u00b6bel","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Fox","length":289.25342,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":1060,"song":"Riecht wie Teen Spirit (Smells Like Teen Spirit)","status":200,"ts":1543588676796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Eisbrecher","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":33,"lastName":"Cuevas","length":241.89342,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Adrenalin","status":200,"ts":1543588717796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ryan Bingham","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":0,"lastName":"George","length":247.30077,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Bread & Water","status":200,"ts":1543588866796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Ashanti","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":19,"lastName":"Young","length":282.46159,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"VooDoo","status":200,"ts":1543588921796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":34,"lastName":"Cuevas","length":277.15873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1543588958796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Clint Eastwood","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":2,"lastName":"Fox","length":65.25342,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":1060,"song":"Frankie's Office","status":200,"ts":1543588965796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Charttraxx Karaoke","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":3,"lastName":"Fox","length":225.17506,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":1060,"song":"Fireflies","status":200,"ts":1543589030796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Jason Mraz","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":1,"lastName":"George","length":264.69832,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Summer Breeze","status":200,"ts":1543589113796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The B-52's","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":20,"lastName":"Young","length":321.54077,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Love Shack","status":200,"ts":1543589203796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Aventura","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":4,"lastName":"Fox","length":242.1024,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":1060,"song":"Alexandra","status":200,"ts":1543589255796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Five Iron Frenzy","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":2,"lastName":"George","length":236.09424,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Canada","status":200,"ts":1543589377796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"12 Stones","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":5,"lastName":"Fox","length":184.0322,"level":"free","location":"New Orleans-Metairie, LA","method":"PUT","page":"NextSong","registration":1541033612796.0,"sessionId":1060,"song":"Anthem For The Underdog","status":200,"ts":1543589497796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Kings Of Leon","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":21,"lastName":"Young","length":201.79546,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Revelry","status":200,"ts":1543589524796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Brooklyn Bounce","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":3,"lastName":"George","length":359.13098,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Get Ready To Bounce Recall 08","status":200,"ts":1543589613796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Dashboard Confessional","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":22,"lastName":"Young","length":147.30404,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"The Good Fight","status":200,"ts":1543589725796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":35,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Downgrade","registration":1540940782796.0,"sessionId":1096,"song":null,"status":200,"ts":1543589847796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Lonnie Johnson","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":23,"lastName":"Young","length":194.55955,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Low Land Moan","status":200,"ts":1543589872796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":0,"lastName":null,"length":null,"level":"paid","location":null,"method":"PUT","page":"Login","registration":null,"sessionId":1097,"song":null,"status":307,"ts":1543589944796,"userAgent":null,"userId":""} {"artist":null,"auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":1,"lastName":"Rodriguez","length":null,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"GET","page":"Home","registration":1540511766796.0,"sessionId":1097,"song":null,"status":200,"ts":1543589968796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Leggo Beast","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":2,"lastName":"Rodriguez","length":376.58077,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":1097,"song":"In","status":200,"ts":1543589971796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"The Pussycat Dolls","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":4,"lastName":"George","length":190.95465,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Sway","status":200,"ts":1543589972796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Stereophonics","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":24,"lastName":"Young","length":290.53342,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"I Miss You Now","status":200,"ts":1543590066796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Beautiful South","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":5,"lastName":"George","length":236.5122,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Masculine Eclipse","status":200,"ts":1543590162796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Acacia Strain","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":3,"lastName":"Rodriguez","length":194.21995,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":1097,"song":"As If Set Afire","status":200,"ts":1543590347796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"ATB","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":25,"lastName":"Young","length":251.48036,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Underwater World","status":200,"ts":1543590356796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Robert Cray Band","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":6,"lastName":"George","length":309.52444,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Our Last Time","status":200,"ts":1543590398796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Enigma","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":4,"lastName":"Rodriguez","length":242.78159,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":1097,"song":"T.N.T. For The Brain (112 Bpm) (Radio Edit)","status":200,"ts":1543590541796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Amon Amarth","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":26,"lastName":"Young","length":268.2771,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Tattered Banners And Bloody Flags","status":200,"ts":1543590607796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"We Are Scientists","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":7,"lastName":"George","length":198.89587,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"The Great Escape (Album Version) (Explicit)","status":200,"ts":1543590707796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Roberto Murolo","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":0,"lastName":"Jones","length":188.02893,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":1100,"song":"Lacreme napulitane","status":200,"ts":1543590774796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Ashlee Simpson","auth":"Logged In","firstName":"Mohammad","gender":"M","itemInSession":5,"lastName":"Rodriguez","length":214.43873,"level":"paid","location":"Sacramento--Roseville--Arden-Arcade, CA","method":"PUT","page":"NextSong","registration":1540511766796.0,"sessionId":1097,"song":"Autobiography","status":200,"ts":1543590783796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"88"} {"artist":"Metallica","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":27,"lastName":"Young","length":152.60689,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"The Ecstasy Of Gold","status":200,"ts":1543590875796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"3 Doors Down","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":8,"lastName":"George","length":233.74322,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Kryptonite","status":200,"ts":1543590905796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Hazell Dean","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":1,"lastName":"Jones","length":367.98649,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":1100,"song":"No Fool (For Love)","status":200,"ts":1543590962796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Apocalyptica","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":28,"lastName":"Young","length":262.5824,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Pray","status":200,"ts":1543591027796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":9,"lastName":"George","length":236.93016,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Bubble Toes","status":200,"ts":1543591138796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Cage The Elephant","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":29,"lastName":"Young","length":196.38812,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Lotus","status":200,"ts":1543591289796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Taylor Swift","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":2,"lastName":"Jones","length":230.47791,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":1100,"song":"You Belong With Me","status":200,"ts":1543591329796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":36,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":1096,"song":null,"status":200,"ts":1543591344796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Soul For Real","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":10,"lastName":"George","length":271.25506,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Candy Rain","status":200,"ts":1543591374796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Prodigy","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":30,"lastName":"Young","length":225.09669,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Firestarter","status":200,"ts":1543591485796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Amy Winehouse","auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":3,"lastName":"Jones","length":165.11955,"level":"paid","location":"Janesville-Beloit, WI","method":"PUT","page":"NextSong","registration":1541062818796.0,"sessionId":1100,"song":"Addicted","status":200,"ts":1543591559796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":null,"auth":"Logged In","firstName":"Matthew","gender":"M","itemInSession":4,"lastName":"Jones","length":null,"level":"paid","location":"Janesville-Beloit, WI","method":"GET","page":"Error","registration":1541062818796.0,"sessionId":1100,"song":null,"status":404,"ts":1543591614796,"userAgent":"\"Mozilla\/5.0 (Windows NT 5.1) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"36"} {"artist":"Iron Maiden","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":11,"lastName":"George","length":275.19955,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"The Evil That Men Do (1998 Digital Remaster)","status":200,"ts":1543591645796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"David Crowder*Band","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":31,"lastName":"Young","length":276.74077,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"All Around Me","status":200,"ts":1543591710796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"The Cinematic Orchestra","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":12,"lastName":"George","length":622.2624,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Everyday","status":200,"ts":1543591920796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Three 6 Mafia vs. Ti\u00c3\u0083\u00c2\u00absto with Sean Kingston and Flo Rida","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":32,"lastName":"Young","length":241.05751,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Feel It","status":200,"ts":1543591986796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Sugababes","auth":"Logged In","firstName":"Kinsley","gender":"F","itemInSession":33,"lastName":"Young","length":275.93098,"level":"paid","location":"Red Bluff, CA","method":"PUT","page":"NextSong","registration":1540465241796.0,"sessionId":977,"song":"Overload","status":200,"ts":1543592227796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_10_0) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"85"} {"artist":"Gyptian","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":13,"lastName":"George","length":233.09016,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Hold You","status":200,"ts":1543592542796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Zion \/ Akon","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":14,"lastName":"George","length":233.19465,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"The Way She Moves","status":200,"ts":1543592775796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Transvision Vamp","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":15,"lastName":"George","length":209.91955,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"I Want Your Love","status":200,"ts":1543593008796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Ry Cooder","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":37,"lastName":"Cuevas","length":201.56036,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Corrido de Boxeo","status":200,"ts":1543593062796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Pussycat Dolls","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":16,"lastName":"George","length":245.18485,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"When I Grow Up","status":200,"ts":1543593217796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Coldplay","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":38,"lastName":"Cuevas","length":268.30322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Yellow","status":200,"ts":1543593263796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Forever The Sickest Kids","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":17,"lastName":"George","length":169.482,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"She Likes (Bittersweet Love)","status":200,"ts":1543593462796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Lil Wayne \/ Blaque \/ Mannie Fresh","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":39,"lastName":"Cuevas","length":255.34649,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Believe That","status":200,"ts":1543593531796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dragonforce","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":18,"lastName":"George","length":441.02485,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Through The Fire And Flames (Album Version)","status":200,"ts":1543593631796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Jason Mraz & Colbie Caillat","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":40,"lastName":"Cuevas","length":189.6224,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Lucky (Album Version)","status":200,"ts":1543593786796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Pixies","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":41,"lastName":"Cuevas","length":181.13261,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Is She Weird","status":200,"ts":1543593975796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eminem","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":19,"lastName":"George","length":251.55873,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Without Me","status":200,"ts":1543594072796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Buju Banton","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":42,"lastName":"Cuevas","length":232.48934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Cry No More","status":200,"ts":1543594156796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Cage The Elephant","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":20,"lastName":"George","length":196.38812,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Lotus","status":200,"ts":1543594323796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Barry Tuckwell\/Academy of St Martin-in-the-Fields\/Sir Neville Marriner","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":43,"lastName":"Cuevas","length":277.15873,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Horn Concerto No. 4 in E flat K495: II. Romance (Andante cantabile)","status":200,"ts":1543594388796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ste Strausz","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":21,"lastName":"George","length":285.36118,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Le Million","status":200,"ts":1543594519796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Coldplay","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":44,"lastName":"Cuevas","length":228.62322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Only Superstition","status":200,"ts":1543594665796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Joe Christmas","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Roth","length":185.7824,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":1059,"song":"Bedroom Suite","status":200,"ts":1543594698796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":"Bright Eyes","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":22,"lastName":"George","length":313.23383,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"A New Arrangement","status":200,"ts":1543594804796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Paramore","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Roth","length":267.65016,"level":"free","location":"Indianapolis-Carmel-Anderson, IN","method":"PUT","page":"NextSong","registration":1540699429796.0,"sessionId":1059,"song":"The Only Exception (Album Version)","status":200,"ts":1543594883796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"78"} {"artist":"J. Karjalainen & Mustat Lasit","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":45,"lastName":"Cuevas","length":336.74404,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Sinisten t\u00c3\u0083\u00c2\u00a4htien alla","status":200,"ts":1543594893796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":null,"auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Fox","length":null,"level":"free","location":"New Orleans-Metairie, LA","method":"GET","page":"Home","registration":1541033612796.0,"sessionId":1108,"song":null,"status":200,"ts":1543594901796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.3; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.143 Safari\/537.36\"","userId":"101"} {"artist":"Philip Glass","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":23,"lastName":"George","length":368.40444,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Knee 2","status":200,"ts":1543595117796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":46,"lastName":"Cuevas","length":195.94404,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1096,"song":"Sincerit\u00c3\u0083\u00c2\u00a9 Et Jalousie","status":200,"ts":1543595229796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Mew","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":24,"lastName":"George","length":167.75791,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Her Voice Is Beyond Her Years","status":200,"ts":1543595485796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":0,"lastName":"Cuevas","length":null,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"GET","page":"Home","registration":1540940782796.0,"sessionId":1114,"song":null,"status":200,"ts":1543595652796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Ive Mendes","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":25,"lastName":"George","length":238.94159,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"If You Leave Me Now","status":200,"ts":1543595652796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":0,"lastName":"Harris","length":null,"level":"free","location":"Eugene, OR","method":"GET","page":"Home","registration":1540906915796.0,"sessionId":1026,"song":null,"status":200,"ts":1543595722796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Alliance Ethnik","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":1,"lastName":"Harris","length":195.94404,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":1026,"song":"Sincerit\u00c3\u0083\u00c2\u00a9 Et Jalousie","status":200,"ts":1543595757796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"the bird and the bee","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":26,"lastName":"George","length":193.802,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Diamond Dave","status":200,"ts":1543595890796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Common \/ Sadat X","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":2,"lastName":"Harris","length":256.20853,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":1026,"song":"1999","status":200,"ts":1543595952796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":null,"auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":3,"lastName":"Harris","length":null,"level":"free","location":"Eugene, OR","method":"GET","page":"Upgrade","registration":1540906915796.0,"sessionId":1026,"song":null,"status":200,"ts":1543596017796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":null,"auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":4,"lastName":"Harris","length":null,"level":"free","location":"Eugene, OR","method":"GET","page":"Upgrade","registration":1540906915796.0,"sessionId":1026,"song":null,"status":200,"ts":1543596021796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Alanis Morissette","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":27,"lastName":"George","length":245.15873,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"King Of Pain (Live\/Unplugged Version)","status":200,"ts":1543596083796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":5,"lastName":"Harris","length":null,"level":"free","location":"Eugene, OR","method":"GET","page":"Home","registration":1540906915796.0,"sessionId":1026,"song":null,"status":200,"ts":1543596176796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":null,"auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":6,"lastName":"Harris","length":null,"level":"free","location":"Eugene, OR","method":"GET","page":"Upgrade","registration":1540906915796.0,"sessionId":1026,"song":null,"status":200,"ts":1543596200796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"Skillet","auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":7,"lastName":"Harris","length":233.32526,"level":"free","location":"Eugene, OR","method":"PUT","page":"NextSong","registration":1540906915796.0,"sessionId":1026,"song":"Rebirthing (Album Version)","status":200,"ts":1543596208796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":null,"auth":"Logged In","firstName":"Bronson","gender":"M","itemInSession":8,"lastName":"Harris","length":null,"level":"free","location":"Eugene, OR","method":"PUT","page":"Logout","registration":1540906915796.0,"sessionId":1026,"song":null,"status":307,"ts":1543596209796,"userAgent":"\"Mozilla\/5.0 (Windows NT 6.1; WOW64) AppleWebKit\/537.36 (KHTML, like Gecko) Chrome\/36.0.1985.125 Safari\/537.36\"","userId":"33"} {"artist":"James Galway;Julian Lee","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":28,"lastName":"George","length":218.67057,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Beauty and the Beast","status":200,"ts":1543596328796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged Out","firstName":null,"gender":null,"itemInSession":9,"lastName":null,"length":null,"level":"free","location":null,"method":"GET","page":"Home","registration":null,"sessionId":1026,"song":null,"status":200,"ts":1543596347796,"userAgent":null,"userId":""} {"artist":"Drop Dead_ Gorgeous","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":29,"lastName":"George","length":156.70812,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Dressed For Friend Requests (Album Version)","status":200,"ts":1543596546796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Dwight Yoakam","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":30,"lastName":"George","length":239.3073,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"You're The One","status":200,"ts":1543596702796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Trouble","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":31,"lastName":"George","length":205.11302,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Tuesday's Child","status":200,"ts":1543596941796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":32,"lastName":"George","length":null,"level":"paid","location":"Birmingham-Hoover, AL","method":"GET","page":"Downgrade","registration":1541020249796.0,"sessionId":1076,"song":null,"status":200,"ts":1543596972796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"OneRepublic","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":33,"lastName":"George","length":237.97506,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"All The Right Moves","status":200,"ts":1543597146796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Switchblade Symphony","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":34,"lastName":"George","length":259.5522,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Wicked","status":200,"ts":1543597383796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Sharooz","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":35,"lastName":"George","length":234.05669,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"My Distressor 40Khz ReRub Mix","status":200,"ts":1543597642796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Explosions In The Sky","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":36,"lastName":"George","length":522.9971,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Six Days At The Bottom Of The Ocean","status":200,"ts":1543597876796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Austin","gender":"M","itemInSession":0,"lastName":"Rosales","length":null,"level":"free","location":"New York-Newark-Jersey City, NY-NJ-PA","method":"GET","page":"Home","registration":1541059521796.0,"sessionId":1101,"song":null,"status":200,"ts":1543598001796,"userAgent":"Mozilla\/5.0 (Windows NT 6.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"12"} {"artist":"Emmylou Harris","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":1,"lastName":"Cuevas","length":194.63791,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Little Bird","status":200,"ts":1543598174796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Jack Johnson","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":2,"lastName":"Cuevas","length":153.67791,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"The Horizon Has Been Defeated","status":200,"ts":1543598368796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Radiohead","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":37,"lastName":"George","length":249.93914,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Everything In Its Right Place","status":200,"ts":1543598398796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Andrew Bird","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":3,"lastName":"Cuevas","length":215.87546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Heretics","status":200,"ts":1543598521796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Metallica","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":38,"lastName":"George","length":380.21179,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Sabbra Cadabra","status":200,"ts":1543598647796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Lonnie Gordon","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":4,"lastName":"Cuevas","length":181.21098,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Catch You Baby (Steve Pitron & Max Sanna Radio Edit)","status":200,"ts":1543598736796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Dropkick Murphys","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":5,"lastName":"Cuevas","length":167.73179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Shattered","status":200,"ts":1543598917796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Eric B. & Rakim","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":39,"lastName":"George","length":240.32608,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"As The Rhyme Goes On","status":200,"ts":1543599027796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Dierks Bentley","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":6,"lastName":"Cuevas","length":223.242,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Settle For A Slowdown","status":200,"ts":1543599084796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Regina Spektor","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":40,"lastName":"George","length":290.14159,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Daniel Cowman","status":200,"ts":1543599267796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Angelspit","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":7,"lastName":"Cuevas","length":241.94567,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Make You Sin","status":200,"ts":1543599307796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Young Gunz \/ Beanie Sigel","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":8,"lastName":"Cuevas","length":292.44036,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Roc U","status":200,"ts":1543599548796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"DJ Dizzy","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":41,"lastName":"George","length":221.1522,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Sexy Bitch","status":200,"ts":1543599557796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Base Ball Bear","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":42,"lastName":"George","length":255.60771,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Sayonara-Nostalgia","status":200,"ts":1543599778796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Morcheeba","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":9,"lastName":"Cuevas","length":101.95546,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"In The Hands Of The Gods (Featuring Biz Markie)","status":200,"ts":1543599840796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Bitter:Sweet","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":10,"lastName":"Cuevas","length":194.16771,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Don't Forget To Breathe","status":200,"ts":1543599941796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Basshunter Feat. DJ Mental Theo\u0019s Bazzheadz","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":43,"lastName":"George","length":152.65914,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Now You're Gone","status":200,"ts":1543600033796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Bj\u00c3\u0083\u00c2\u00b6rk","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":11,"lastName":"Cuevas","length":348.57751,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Undo","status":200,"ts":1543600135796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Rihanna","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":44,"lastName":"George","length":239.75138,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"G4L","status":200,"ts":1543600185796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Evanescence","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":45,"lastName":"George","length":220.3424,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Hello","status":200,"ts":1543600424796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Mr. Vegas","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":12,"lastName":"Cuevas","length":240.69179,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Tamale","status":200,"ts":1543600483796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Mischa Daniels","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":46,"lastName":"George","length":419.81342,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Another Place","status":200,"ts":1543600644796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"The Menzingers","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":13,"lastName":"Cuevas","length":276.00934,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Straight To Hell","status":200,"ts":1543600723796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Justin Timberlake","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":14,"lastName":"Cuevas","length":288.93995,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Cry Me A River","status":200,"ts":1543600999796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Vilma Palma e Vampiros","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":47,"lastName":"George","length":338.18077,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Un Camino Hasta Vos","status":200,"ts":1543601063796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"CCCP - Fedeli Alla Linea","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":15,"lastName":"Cuevas","length":329.66485,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Sura (2008 Digital Remaster)","status":200,"ts":1543601287796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Kid Cudi \/ MGMT \/ Ratatat","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":48,"lastName":"George","length":295.67955,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Pursuit Of Happiness (nightmare)","status":200,"ts":1543601401796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Drake \/ Kanye West \/ Lil Wayne \/ Eminem","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":16,"lastName":"Cuevas","length":357.66812,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Forever","status":200,"ts":1543601616796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"A Day To Remember","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":49,"lastName":"George","length":247.64036,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Homesick [Acoustic]","status":200,"ts":1543601696796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"T.I.","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":0,"lastName":"Bell","length":299.75465,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540991795796.0,"sessionId":1085,"song":"Dead And Gone [feat. Justin Timberlake] (Explicit Album Version)","status":200,"ts":1543601780796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 10.0; Windows NT 6.2; WOW64; Trident\/6.0)","userId":"91"} {"artist":"The Offspring","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":50,"lastName":"George","length":163.3171,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"It'll Be a Long Time (Album Version)","status":200,"ts":1543601943796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Jorge Gonzalez","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":17,"lastName":"Cuevas","length":272.14322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Esta Es Para Hacerte F\u00c3\u0083\u00c2\u00a9liz","status":200,"ts":1543601973796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sneaker Pimps","auth":"Logged In","firstName":"Jayden","gender":"M","itemInSession":1,"lastName":"Bell","length":260.91057,"level":"free","location":"Dallas-Fort Worth-Arlington, TX","method":"PUT","page":"NextSong","registration":1540991795796.0,"sessionId":1085,"song":"Spin Spin Sugar","status":200,"ts":1543602079796,"userAgent":"Mozilla\/5.0 (compatible; MSIE 10.0; Windows NT 6.2; WOW64; Trident\/6.0)","userId":"91"} {"artist":"Escape The Fate","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":51,"lastName":"George","length":266.73587,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"This War Is Ours (The Guillotine II)","status":200,"ts":1543602106796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Juanes","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":18,"lastName":"Cuevas","length":243.27791,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"La Vida Es Un Ratico","status":200,"ts":1543602245796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"The Replacements","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":52,"lastName":"George","length":170.57914,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Never Mind","status":200,"ts":1543602372796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Sarah McLachlan","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":19,"lastName":"Cuevas","length":278.90893,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Possession","status":200,"ts":1543602488796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Sonny Boy Williamson","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":53,"lastName":"George","length":152.24118,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Don't Start Me Talkin'","status":200,"ts":1543602542796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Soul II Soul Featuring Caron Wheeler","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":54,"lastName":"George","length":225.2273,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Back To Life (However Do You Want Me) (2003 Digital Remaster) (Feat. Caron Wheeler)","status":200,"ts":1543602694796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Florence + The Machine","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":20,"lastName":"Cuevas","length":219.66322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Dog Days Are Over (Radio Edit)","status":200,"ts":1543602766796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Pantera","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":55,"lastName":"George","length":286.69342,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Heresy (LP Version)","status":200,"ts":1543602919796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":56,"lastName":"George","length":null,"level":"paid","location":"Birmingham-Hoover, AL","method":"GET","page":"Help","registration":1541020249796.0,"sessionId":1076,"song":null,"status":200,"ts":1543602936796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Cold","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":21,"lastName":"Cuevas","length":177.76281,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Remedy","status":200,"ts":1543602985796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Norther","auth":"Logged In","firstName":"Chloe","gender":"F","itemInSession":22,"lastName":"Cuevas","length":246.54322,"level":"paid","location":"San Francisco-Oakland-Hayward, CA","method":"PUT","page":"NextSong","registration":1540940782796.0,"sessionId":1114,"song":"Frozen Angel","status":200,"ts":1543603162796,"userAgent":"Mozilla\/5.0 (Windows NT 5.1; rv:31.0) Gecko\/20100101 Firefox\/31.0","userId":"49"} {"artist":"Foo Fighters","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":57,"lastName":"George","length":271.38567,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"The Pretender","status":200,"ts":1543603205796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Timbiriche","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":58,"lastName":"George","length":202.60526,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Besos De Ceniza","status":200,"ts":1543603476796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"A Perfect Circle","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":59,"lastName":"George","length":206.05342,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"Rose","status":200,"ts":1543603678796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Anberlin","auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":60,"lastName":"George","length":348.682,"level":"paid","location":"Birmingham-Hoover, AL","method":"PUT","page":"NextSong","registration":1541020249796.0,"sessionId":1076,"song":"The Haunting","status":200,"ts":1543603884796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":null,"auth":"Logged In","firstName":"Rylan","gender":"M","itemInSession":61,"lastName":"George","length":null,"level":"paid","location":"Birmingham-Hoover, AL","method":"GET","page":"Downgrade","registration":1541020249796.0,"sessionId":1076,"song":null,"status":200,"ts":1543603993796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"16"} {"artist":"Deas Vail","auth":"Logged In","firstName":"Elijah","gender":"M","itemInSession":0,"lastName":"Davis","length":237.68771,"level":"free","location":"Detroit-Warren-Dearborn, MI","method":"PUT","page":"NextSong","registration":1540772343796.0,"sessionId":985,"song":"Anything You Say (Unreleased Version)","status":200,"ts":1543607664796,"userAgent":"\"Mozilla\/5.0 (Macintosh; Intel Mac OS X 10_9_4) AppleWebKit\/537.77.4 (KHTML, like Gecko) Version\/7.0.5 Safari\/537.77.4\"","userId":"5"}
455.731959
577
0.698298
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
Bud1 mpAlg1ScompAmoDDdutcØoéFAmodDdutcØoéFAph1ScompAvSrnlongBlg1ScompBmoDDdutcØoécBmodDdutcØoécBph1ScompBvSrnlongClg1ScompCmoDDdutcØoévCmodDdutcØoévCph1Scomp  @€ @€ @€ @ E DSDB `€ @€ @€ @
6,148
6,148
0.026187
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"num_songs": 1, "artist_id": "ARD7TVE1187B99BFB1", "artist_latitude": null, "artist_longitude": null, "artist_location": "California - LA", "artist_name": "Casual", "song_id": "SOMZWCG12A8C13C480", "title": "I Didn't Mean To", "duration": 218.93179, "year": 0}
261
261
0.67433
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"num_songs": 1, "artist_id": "ARMJAGH1187FB546F3", "artist_latitude": 35.14968, "artist_longitude": -90.04892, "artist_location": "Memphis, TN", "artist_name": "The Box Tops", "song_id": "SOCIWDW12A8C13D406", "title": "Soul Deep", "duration": 148.03546, "year": 1969}
268
268
0.679104
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"num_songs": 1, "artist_id": "ARKRRTF1187B9984DA", "artist_latitude": null, "artist_longitude": null, "artist_location": "", "artist_name": "Sonora Santanera", "song_id": "SOXVLOJ12AB0189215", "title": "Amor De Cabaret", "duration": 177.47546, "year": 0}
255
255
0.682353
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"num_songs": 1, "artist_id": "AR7G5I41187FB4CE6C", "artist_latitude": null, "artist_longitude": null, "artist_location": "London, England", "artist_name": "Adam Ant", "song_id": "SONHOTT12A8C13493C", "title": "Something Girls", "duration": 233.40363, "year": 1982}
265
265
0.690566
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"num_songs": 1, "artist_id": "ARXR32B1187FB57099", "artist_latitude": null, "artist_longitude": null, "artist_location": "", "artist_name": "Gob", "song_id": "SOFSOCN12A8C143F5D", "title": "Face the Ashes", "duration": 209.60608, "year": 2007}
244
244
0.672131
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"num_songs": 1, "artist_id": "ARKFYS91187B98E58F", "artist_latitude": null, "artist_longitude": null, "artist_location": "", "artist_name": "Jeff And Sheri Easter", "song_id": "SOYMRWW12A6D4FAB14", "title": "The Moon And I (Ordinary Day Album Version)", "duration": 267.7024, "year": 0}
287
287
0.686411
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"num_songs": 1, "artist_id": "ARD0S291187B9B7BF5", "artist_latitude": null, "artist_longitude": null, "artist_location": "Ohio", "artist_name": "Rated R", "song_id": "SOMJBYD12A6D4F8557", "title": "Keepin It Real (Skit)", "duration": 114.78159, "year": 0}
256
256
0.671875
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"num_songs": 1, "artist_id": "AR10USD1187B99F3F1", "artist_latitude": null, "artist_longitude": null, "artist_location": "Burlington, Ontario, Canada", "artist_name": "Tweeterfriendly Music", "song_id": "SOHKNRJ12A6701D1F8", "title": "Drop of Rain", "duration": 189.57016, "year": 0}
284
284
0.700704
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"num_songs": 1, "artist_id": "AR8ZCNI1187B9A069B", "artist_latitude": null, "artist_longitude": null, "artist_location": "", "artist_name": "Planet P Project", "song_id": "SOIAZJW12AB01853F1", "title": "Pink World", "duration": 269.81832, "year": 1984}
253
253
0.679842
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"num_songs": 1, "artist_id": "ARNTLGG11E2835DDB9", "artist_latitude": null, "artist_longitude": null, "artist_location": "", "artist_name": "Clp", "song_id": "SOUDSGM12AC9618304", "title": "Insatiable (Instrumental Version)", "duration": 266.39628, "year": 0}
260
260
0.684615
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"num_songs": 1, "artist_id": "ARGSJW91187B9B1D6B", "artist_latitude": 35.21962, "artist_longitude": -80.01955, "artist_location": "North Carolina", "artist_name": "JennyAnyKind", "song_id": "SOQHXMF12AB0182363", "title": "Young Boy Blues", "duration": 218.77506, "year": 0}
274
274
0.693431
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"num_songs": 1, "artist_id": "ARC43071187B990240", "artist_latitude": null, "artist_longitude": null, "artist_location": "Wisner, LA", "artist_name": "Wayne Watson", "song_id": "SOKEJEJ12A8C13E0D0", "title": "The Urgency (LP Version)", "duration": 245.21098, "year": 0}
270
270
0.681481
Udacity-Data-Engineering-Projects
https://github.com/san089/Udacity-Data-Engineering-Projects
Few projects related to Data Engineering including Data Modeling, Infrastructure setup on cloud, Data Warehousing and Data Lake development.
1,219
433
2023-12-04 20:08:27+00:00
2020-01-20 22:50:03+00:00
2,128
Other
Misc
{"num_songs": 1, "artist_id": "ARL7K851187B99ACD2", "artist_latitude": null, "artist_longitude": null, "artist_location": "", "artist_name": "Andy Andy", "song_id": "SOMUYGI12AB0188633", "title": "La Culpa", "duration": 226.35057, "year": 0}
241
241
0.66805